2025.07.28 06:04:08.567283 [ 413 ] {} Context: Server was built with thread sanitizer. It will work slowly. 2025.07.28 06:04:10.135798 [ 413 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.07.28 06:04:10.137208 [ 413 ] {} KeeperLogStore: Removing all changelogs 2025.07.28 06:04:10.138535 [ 413 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.07.28 06:04:10.151798 [ 413 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.07.28 06:04:10.151886 [ 413 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.07.28 06:04:10.204304 [ 1003 ] {} RaftInstance: Election timeout, initiate leader election 2025.07.28 06:04:10.289569 [ 413 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.07.28 06:04:10.289664 [ 413 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.07.28 06:04:10.327354 [ 413 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.07.28 06:04:10.329969 [ 413 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.07.28 06:04:28.623863 [ 419 ] {716a743f-8a33-4571-a363-0be03c85cc9f} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE hits_v1; to attach existing table or CREATE TABLE hits_v1 ; to create new table or ATTACH TABLE hits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.07.28 06:04:39.012743 [ 419 ] {7ed2438a-0ac9-4a7c-9cf0-2c7a0190ad0b} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE visits_v1; to attach existing table or CREATE TABLE visits_v1
; to create new table or ATTACH TABLE visits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.07.28 06:07:56.384963 [ 1807 ] {0e28b6ec-1569-469a-8d3e-83101a471746} DistributedSink: Structure does not match (remote: n UInt64 UInt64(size = 0), local: n Int32 Int32(size = 1)), implicit conversion will be done. 2025.07.28 06:07:56.495618 [ 1807 ] {10f3b8ad-341f-4dcb-8b5a-dc80373e0b16} StorageBuffer (test_e291ek3i._tmp_replace_4d59ef643a35e9d6_rylakifb1cbc2801): Destination table test_e291ek3i.t have different type of column n (UInt64 != Int32). Block of data is converted. 2025.07.28 06:07:56.547606 [ 1807 ] {2122d01c-ba8c-4855-b69e-59f68528edbc} DistributedSink: Structure does not match (remote: n UInt64 UInt64(size = 0), local: n Int32 Int32(size = 1)), implicit conversion will be done. 2025.07.28 06:07:56.908660 [ 1807 ] {0a4a738b-4ab3-4114-b8fc-ebe83ffdd8cd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(n :: 0) -> throwIf(__table1.n) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35906) (comment: 01157_replace_table.sql) (query 23, line 31) (in query: -- table is not created if select fails create or replace table join engine=Join(ANY, INNER, n) as select * from t where throwIf(n);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ecc1 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:07:57.023945 [ 1807 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(n :: 0) -> throwIf(__table1.n) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ecc1 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1929: DB::executeTrivialBlockIO(DB::BlockIO&, std::shared_ptr) @ 0x0000000018e20616 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2135: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x00000000188ca127 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5e81 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:07:57.147631 [ 1807 ] {23db8583-9f36-4a8e-96bb-3bfaf7394de3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(n :: 0) -> throwIf(__table1.n) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35906) (comment: 01157_replace_table.sql) (query 28, line 41) (in query: replace table join engine=Join(ANY, INNER, n) as select * from t where throwIf(n);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ecc1 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:07:57.149131 [ 1807 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(n :: 0) -> throwIf(__table1.n) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ecc1 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1929: DB::executeTrivialBlockIO(DB::BlockIO&, std::shared_ptr) @ 0x0000000018e20616 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2135: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x00000000188ca127 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5e81 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:08:00.867992 [ 1851 ] {397c3083-19d2-4240-b5c9-8853939b949f} executeQuery: Code: 392. DB::Exception: Schema inference is not supported with allow_experimental_analyzer=0 for INSERT INTO FUNCTION ... SELECT FROM input(). (QUERY_IS_PROHIBITED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35634) (comment: 03380_input_async_insert.sql) (query 4, line 11) (in query: --- --- Non-analyzer - does not support INSERT INTO FUNCTION null('auto') SELECT FROM input() --- insert into function null() select * from input('x Int, y String') settings async_insert=1, allow_experimental_analyzer=0 format JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:141: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018911923 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:00.870507 [ 1851 ] {} TCPHandler: Code: 392. DB::Exception: Schema inference is not supported with allow_experimental_analyzer=0 for INSERT INTO FUNCTION ... SELECT FROM input(). (QUERY_IS_PROHIBITED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:141: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018911923 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:01.283052 [ 1856 ] {d86ac633-c51a-481d-8d05-b1948a264608} executeQuery: Code: 691. DB::Exception: Unexpected value 2 in enum: while executing 'FUNCTION toString(__table1.v :: 0) -> toString(__table1.v) String : 1'. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35646) (comment: 01263_type_conversion_nvartolomei.sql) (query 15, line 46) (in query: SELECT toString(v) FROM (SELECT v FROM d ORDER BY v) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000a119ce6 5. ./src/DataTypes/EnumValues.h:54: COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001635a5fb 6. ./src/Functions/FunctionsConversion.h:2472: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620ebd0 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620e1e0 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:08:01.318031 [ 1861 ] {920677ea-5002-4d70-84ab-f373c416c44a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_op2z4x35.landing_to_target (20042447-6e8b-44af-be5e-deac9b4977f4). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35718) (comment: 02345_implicit_transaction.sql) (query 4, line 9) (in query: INSERT INTO landing SELECT * FROM numbers(10000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:845: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000001c1b3c12 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b06fc 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afe55 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:08:01.373114 [ 1861 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_op2z4x35.landing_to_target (20042447-6e8b-44af-be5e-deac9b4977f4). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:845: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000001c1b3c12 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b06fc 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afe55 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:08:01.383633 [ 1856 ] {} TCPHandler: Code: 691. DB::Exception: Unexpected value 2 in enum: while executing 'FUNCTION toString(__table1.v :: 0) -> toString(__table1.v) String : 1'. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000a119ce6 5. ./src/DataTypes/EnumValues.h:54: COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001635a5fb 6. ./src/Functions/FunctionsConversion.h:2472: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620ebd0 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620e1e0 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:01.527841 [ 1861 ] {1a511ab6-ea7f-4e3d-85be-daf377c602bc} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_op2z4x35.landing_to_target (20042447-6e8b-44af-be5e-deac9b4977f4). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35718) (comment: 02345_implicit_transaction.sql) (query 10, line 18) (in query: INSERT INTO landing SELECT * FROM numbers(10000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:845: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000001c1b3c12 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b06fc 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afe55 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:08:01.531052 [ 1861 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_op2z4x35.landing_to_target (20042447-6e8b-44af-be5e-deac9b4977f4). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:845: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000001c1b3c12 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b06fc 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afe55 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:08:01.649540 [ 1861 ] {feb3c967-e39a-4eb4-af1f-7451521aada1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_op2z4x35.landing_to_target (20042447-6e8b-44af-be5e-deac9b4977f4). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35718) (comment: 02345_implicit_transaction.sql) (query 14, line 23) (in query: -- Same but using implicit_transaction INSERT INTO landing SETTINGS implicit_transaction=True SELECT * FROM numbers(10000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:845: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000001c1b3c12 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b06fc 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afe55 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:08:01.652348 [ 1861 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_op2z4x35.landing_to_target (20042447-6e8b-44af-be5e-deac9b4977f4). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:845: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000001c1b3c12 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b06fc 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afe55 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:08:01.747600 [ 1861 ] {3f4ea46b-dfc3-48ed-aff1-f2cfa38d53e3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_op2z4x35.landing_to_target (20042447-6e8b-44af-be5e-deac9b4977f4). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35718) (comment: 02345_implicit_transaction.sql) (query 18, line 30) (in query: INSERT INTO landing SELECT * FROM numbers(10000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:845: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000001c1b3c12 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b06fc 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afe55 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:08:01.750981 [ 1861 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.n, 3333_UInt16) :: 0) -> throwIf(equals(__table1.n, 3333_UInt16)) UInt8 : 1': while pushing to view test_op2z4x35.landing_to_target (20042447-6e8b-44af-be5e-deac9b4977f4). (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:845: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000001c1b3c12 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b06fc 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afe55 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:08:01.903339 [ 1861 ] {f8e1b5ae-bf87-4736-bf79-182ce80ec704} executeQuery: Code: 48. DB::Exception: Storage SystemSettings (table system.settings (7acf779f-32a3-449b-bb97-faa4ab0f887f)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35718) (comment: 02345_implicit_transaction.sql) (query 22, line 35) (in query: -- Reading from incompatible sources with implicit_transaction works the same way as with normal transactions: -- Currently reading from system tables inside a transaction is Not implemented: SELECT name, value, changed FROM system.settings where name = 'implicit_transaction' SETTINGS implicit_transaction=True;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Planner/Planner.cpp:178: DB::Planner::buildPlanForQueryNode() @ 0x000000001898c4f2 5. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:08:01.904608 [ 1861 ] {} TCPHandler: Code: 48. DB::Exception: Storage SystemSettings (table system.settings (7acf779f-32a3-449b-bb97-faa4ab0f887f)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Planner/Planner.cpp:178: DB::Planner::buildPlanForQueryNode() @ 0x000000001898c4f2 5. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:08:02.020603 [ 1861 ] {b3daf869-d830-4e6c-afa4-f6649ad13913} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35718) (comment: 02345_implicit_transaction.sql) (query 24, line 42) (in query: SELECT throwIf(number == 0) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:08:02.022790 [ 1861 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:02.038649 [ 1861 ] {0c60f394-22ff-4495-aa8f-9195e693bca8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35718) (comment: 02345_implicit_transaction.sql) (query 25, line 43) (in query: SELECT throwIf(number == 0) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:08:02.040248 [ 1861 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:02.057725 [ 1861 ] {ff72b9de-1f67-4dd9-afc1-dff937001533} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35718) (comment: 02345_implicit_transaction.sql) (query 26, line 44) (in query: SELECT throwIf(number == 0) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:08:02.058976 [ 1861 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:02.076897 [ 1861 ] {ad15b0f3-518e-4025-ac1d-275235c3ce5a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35718) (comment: 02345_implicit_transaction.sql) (query 27, line 45) (in query: SELECT throwIf(number == 0) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:08:02.078829 [ 1861 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:02.131341 [ 1861 ] {2147ec36-ce78-4045-b83a-7da3850aae6c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35718) (comment: 02345_implicit_transaction.sql) (query 31, line 51) (in query: SELECT throwIf(number == 0) FROM numbers(100) SETTINGS implicit_transaction=True;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:08:02.134851 [ 1861 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 0_UInt8) :: 0) -> throwIf(equals(__table1.number, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:03.952355 [ 1861 ] {a7e19694-b0d8-4d7d-83d3-184166c4908d} executeQuery: Code: 48. DB::Exception: Storage StorageDummy (table _table_function.cluster) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35718) (comment: 02345_implicit_transaction.sql) (query 49, line 99) (in query: SELECT * FROM cluster('test_cluster_interserver_secret', system, one);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Planner/Planner.cpp:178: DB::Planner::buildPlanForQueryNode() @ 0x000000001898c4f2 5. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 6. ./build_docker/./src/Planner/Planner.cpp:243: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000001897db88 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018979015 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:08:03.954498 [ 1861 ] {} TCPHandler: Code: 48. DB::Exception: Storage StorageDummy (table _table_function.cluster) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Planner/Planner.cpp:178: DB::Planner::buildPlanForQueryNode() @ 0x000000001898c4f2 5. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 6. ./build_docker/./src/Planner/Planner.cpp:243: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000001897db88 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018979015 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:08:03.964274 [ 1861 ] {898387be-0b7c-4d26-b996-d7c65bf380dc} executeQuery: Code: 48. DB::Exception: Storage StorageDummy (table _table_function.cluster) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35718) (comment: 02345_implicit_transaction.sql) (query 50, line 100) (in query: SELECT * FROM cluster('test_cluster_two_shards', system, one);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Planner/Planner.cpp:178: DB::Planner::buildPlanForQueryNode() @ 0x000000001898c4f2 5. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 6. ./build_docker/./src/Planner/Planner.cpp:243: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000001897db88 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018979015 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:08:03.965370 [ 1861 ] {} TCPHandler: Code: 48. DB::Exception: Storage StorageDummy (table _table_function.cluster) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Planner/Planner.cpp:178: DB::Planner::buildPlanForQueryNode() @ 0x000000001898c4f2 5. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 6. ./build_docker/./src/Planner/Planner.cpp:243: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000001897db88 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018979015 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:08:04.074929 [ 1865 ] {61935e74-9786-425a-9e7a-f4cefb94e2a2} executeQuery: Code: 649. DB::Exception: Transaction Control Language queries are allowed only inside session: while starting a transaction with 'implicit_transaction'. (INVALID_TRANSACTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35718) (comment: 02345_implicit_transaction.sql) (query 52, line 102) (in query: SELECT `__table1`.`dummy` AS `dummy` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:25: DB::InterpreterTransactionControlQuery::execute() @ 0x0000000018e27770 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1101: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&)::$_0::operator()(std::shared_ptr const&, DB::ASTTransactionControl::QueryType) const @ 0x0000000018e20ace 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1381: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1581c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:04.076042 [ 1865 ] {} TCPHandler: Code: 649. DB::Exception: Transaction Control Language queries are allowed only inside session: while starting a transaction with 'implicit_transaction'. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:25: DB::InterpreterTransactionControlQuery::execute() @ 0x0000000018e27770 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1101: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&)::$_0::operator()(std::shared_ptr const&, DB::ASTTransactionControl::QueryType) const @ 0x0000000018e20ace 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1381: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1581c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:04.121657 [ 1861 ] {fa962a91-8e23-4a02-93b7-c3915a33db3c} executeQuery: Code: 649. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Transaction Control Language queries are allowed only inside session: while starting a transaction with 'implicit_transaction'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:25: DB::InterpreterTransactionControlQuery::execute() @ 0x0000000018e27770 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1101: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&)::$_0::operator()(std::shared_ptr const&, DB::ASTTransactionControl::QueryType) const @ 0x0000000018e20ace 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1381: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1581c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 : While executing Remote. (INVALID_TRANSACTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35718) (comment: 02345_implicit_transaction.sql) (query 52, line 102) (in query: -- there's not session in the interserver mode SELECT * FROM cluster('test_cluster_interserver_secret', system, one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010c366ad 3. ./build_docker/./src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x000000001ba2a28b 4. ./build_docker/./src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x000000001ba36553 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001ba9d11e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 2025.07.28 06:08:04.125322 [ 1861 ] {} TCPHandler: Code: 649. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Transaction Control Language queries are allowed only inside session: while starting a transaction with 'implicit_transaction'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterTransactionControlQuery.cpp:25: DB::InterpreterTransactionControlQuery::execute() @ 0x0000000018e27770 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1101: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&)::$_0::operator()(std::shared_ptr const&, DB::ASTTransactionControl::QueryType) const @ 0x0000000018e20ace 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1381: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1581c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 : While executing Remote. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010c366ad 3. ./build_docker/./src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x000000001ba2a28b 4. ./build_docker/./src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x000000001ba36553 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001ba9d11e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:07.959803 [ 2061 ] {936c8b23-d09b-4bf4-9853-d489f9bd6708} executeQuery: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `greater(now(), toDateTime('2020-06-01 13:31:40'))`: for Sorting key. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38068) (comment: 01943_non_deterministic_order_key.sql) (query 1, line 1) (in query: CREATE TABLE a (`number` UInt64) ENGINE = MergeTree ORDER BY if(now() > toDateTime('2020-06-01 13:31:40'), toInt64(number), -number) SETTINGS index_granularity = 31312, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 160041322, compact_parts_max_bytes_to_buffer = 148329511, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 29611318, merge_max_block_size = 5797, old_parts_lifetime = 171., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 6892696, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 60471, primary_key_compress_block_size = 25484, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1502: DB::ActionsDAG::assertDeterministic() const @ 0x00000000179dad1d 5. ./build_docker/./src/Interpreters/ExpressionActions.cpp:837: DB::ExpressionActions::assertDeterministic() const @ 0x0000000018303f3a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:664: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x000000001b2eac7f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:859: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000001b2e9c96 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001b2e195a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e0418 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:08:07.961618 [ 2061 ] {} TCPHandler: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `greater(now(), toDateTime('2020-06-01 13:31:40'))`: for Sorting key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1502: DB::ActionsDAG::assertDeterministic() const @ 0x00000000179dad1d 5. ./build_docker/./src/Interpreters/ExpressionActions.cpp:837: DB::ExpressionActions::assertDeterministic() const @ 0x0000000018303f3a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:664: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x000000001b2eac7f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:859: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000001b2e9c96 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001b2e195a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e0418 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:08:07.978907 [ 2061 ] {d8d36021-3f49-47c7-8bd9-035095238759} executeQuery: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `now()`: for Sorting key. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38068) (comment: 01943_non_deterministic_order_key.sql) (query 2, line 2) (in query: CREATE TABLE b (`number` UInt64) ENGINE = MergeTree ORDER BY now() > toDateTime(number) SETTINGS index_granularity = 31312, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 160041322, compact_parts_max_bytes_to_buffer = 148329511, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 29611318, merge_max_block_size = 5797, old_parts_lifetime = 171., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 6892696, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 60471, primary_key_compress_block_size = 25484, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1502: DB::ActionsDAG::assertDeterministic() const @ 0x00000000179dad1d 5. ./build_docker/./src/Interpreters/ExpressionActions.cpp:837: DB::ExpressionActions::assertDeterministic() const @ 0x0000000018303f3a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:664: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x000000001b2eac7f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:859: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000001b2e9c96 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001b2e195a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e0418 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:08:07.981206 [ 2061 ] {} TCPHandler: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `now()`: for Sorting key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1502: DB::ActionsDAG::assertDeterministic() const @ 0x00000000179dad1d 5. ./build_docker/./src/Interpreters/ExpressionActions.cpp:837: DB::ExpressionActions::assertDeterministic() const @ 0x0000000018303f3a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:664: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x000000001b2eac7f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:859: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000001b2e9c96 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001b2e195a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e0418 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:08:07.994167 [ 2061 ] {bd63ea3e-49bd-438c-89c9-2ac46f7d3136} executeQuery: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `now()`: for Sorting key. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38068) (comment: 01943_non_deterministic_order_key.sql) (query 3, line 3) (in query: CREATE TABLE c (`number` UInt64) ENGINE = MergeTree ORDER BY now() SETTINGS index_granularity = 31312, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 160041322, compact_parts_max_bytes_to_buffer = 148329511, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 29611318, merge_max_block_size = 5797, old_parts_lifetime = 171., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 6892696, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 60471, primary_key_compress_block_size = 25484, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1502: DB::ActionsDAG::assertDeterministic() const @ 0x00000000179dad1d 5. ./build_docker/./src/Interpreters/ExpressionActions.cpp:837: DB::ExpressionActions::assertDeterministic() const @ 0x0000000018303f3a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:664: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x000000001b2eac7f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:859: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000001b2e9c96 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001b2e195a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e0418 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:08:07.995472 [ 2061 ] {} TCPHandler: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `now()`: for Sorting key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1502: DB::ActionsDAG::assertDeterministic() const @ 0x00000000179dad1d 5. ./build_docker/./src/Interpreters/ExpressionActions.cpp:837: DB::ExpressionActions::assertDeterministic() const @ 0x0000000018303f3a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:664: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x000000001b2eac7f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:859: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000001b2e9c96 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001b2e195a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e0418 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:08:08.024633 [ 2061 ] {3d3c8066-2007-42f5-8616-83e5b802ecf9} executeQuery: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `plus(plus(now(), 1), 1)`: for Sorting key. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38068) (comment: 01943_non_deterministic_order_key.sql) (query 4, line 4) (in query: CREATE TABLE d (`number` UInt64) ENGINE = MergeTree ORDER BY ((now() + 1) + 1) + number SETTINGS index_granularity = 31312, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 160041322, compact_parts_max_bytes_to_buffer = 148329511, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 29611318, merge_max_block_size = 5797, old_parts_lifetime = 171., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 6892696, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 60471, primary_key_compress_block_size = 25484, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1502: DB::ActionsDAG::assertDeterministic() const @ 0x00000000179dad1d 5. ./build_docker/./src/Interpreters/ExpressionActions.cpp:837: DB::ExpressionActions::assertDeterministic() const @ 0x0000000018303f3a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:664: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x000000001b2eac7f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:859: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000001b2e9c96 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001b2e195a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e0418 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:08:08.026285 [ 2061 ] {} TCPHandler: Code: 36. DB::Exception: Expression must be deterministic but it contains non-deterministic part `plus(plus(now(), 1), 1)`: for Sorting key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1502: DB::ActionsDAG::assertDeterministic() const @ 0x00000000179dad1d 5. ./build_docker/./src/Interpreters/ExpressionActions.cpp:837: DB::ExpressionActions::assertDeterministic() const @ 0x0000000018303f3a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:664: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x000000001b2eac7f 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:859: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000001b2e9c96 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001b2e195a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e0418 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:08:08.403504 [ 2060 ] {8dd76345-17db-4f26-8502-50749475acae} executeQuery: Code: 36. DB::Exception: GROUPING function argument number % 3 is not in GROUP BY keys. In query SELECT number, grouping(number, number % 2, number % 3) AS gr FROM numbers(10) GROUP BY GROUPING SETS ((number), (number % 2)) ORDER BY number ASC, gr ASC. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38106) (comment: 02293_grouping_function.sql) (query 2, line 3) (in query: SELECT number, grouping(number, number % 2, number % 3) AS gr FROM numbers(10) GROUP BY GROUPING SETS ( (number), (number % 2) ) ORDER BY number, gr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:182: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af3ce9 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af38c6 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af38c6 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:354: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af316f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:08:08.404957 [ 2060 ] {} TCPHandler: Code: 36. DB::Exception: GROUPING function argument number % 3 is not in GROUP BY keys. In query SELECT number, grouping(number, number % 2, number % 3) AS gr FROM numbers(10) GROUP BY GROUPING SETS ((number), (number % 2)) ORDER BY number ASC, gr ASC. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:182: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af3ce9 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af38c6 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af38c6 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:354: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af316f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:08:11.211237 [ 419 ] {ead64598-1a14-401a-bb1d-af63b883c9b7} executeQuery: Code: 36. DB::Exception: Second argument to substringIndex must be a single character: In scope SELECT substringIndex('www.clickhouse.com', '..', 2). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38164) (comment: 02798_substring_index.sql) (query 38, line 44) (in query: select substringIndex('www.clickhouse.com', '..', 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ecd8e80 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:08:11.213247 [ 419 ] {} TCPHandler: Code: 36. DB::Exception: Second argument to substringIndex must be a single character: In scope SELECT substringIndex('www.clickhouse.com', '..', 2). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ecd8e80 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:08:11.221477 [ 419 ] {09fb8731-ded9-4236-a192-4f43b8063922} executeQuery: Code: 36. DB::Exception: Second argument to substringIndex must be a single character: In scope SELECT substringIndex('www.clickhouse.com', '', 2). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38164) (comment: 02798_substring_index.sql) (query 39, line 45) (in query: select substringIndex('www.clickhouse.com', '', 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ecd8e80 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:08:11.222724 [ 419 ] {} TCPHandler: Code: 36. DB::Exception: Second argument to substringIndex must be a single character: In scope SELECT substringIndex('www.clickhouse.com', '', 2). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ecd8e80 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:08:11.380422 [ 419 ] {9520a7f3-fcce-429d-b3bd-ec8990a30816} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function substringIndex must be constant. (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38164) (comment: 02798_substring_index.sql) (query 40, line 46) (in query: select substringIndex('www.clickhouse.com', materialize('.'), 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ac8c7a6 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f13d97 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 13. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 14. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:08:11.381976 [ 419 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function substringIndex must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ac8c7a6 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f13d97 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 13. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 14. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:08:11.531182 [ 419 ] {d9abb1c7-9cd4-484d-a7ce-103253542b1d} executeQuery: Code: 43. DB::Exception: Illegal type Int128 of third argument of function substringIndex, Integer expected: In scope SELECT substringIndex('www.clickhouse.com', '.', CAST(2, 'Int128')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38164) (comment: 02798_substring_index.sql) (query 41, line 47) (in query: select substringIndex('www.clickhouse.com', '.', cast(2 as Int128));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::(anonymous namespace)::FunctionSubstringIndex::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ecd9533 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:08:11.532348 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int128 of third argument of function substringIndex, Integer expected: In scope SELECT substringIndex('www.clickhouse.com', '.', CAST(2, 'Int128')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::(anonymous namespace)::FunctionSubstringIndex::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ecd9533 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:08:11.750940 [ 1857 ] {ab1c82ea-e6c9-4e89-870f-969172e4ee83} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 20.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38190) (comment: 02155_read_in_order_max_rows_to_read.sql) (query 10, line 20) (in query: SELECT a FROM t_max_rows_to_read ORDER BY a LIMIT 20 FORMAT Null SETTINGS max_rows_to_read = 12;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000173d8103 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd21a90 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:08:11.752376 [ 1857 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 20.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000173d8103 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd21a90 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:11.772026 [ 1857 ] {2c35c4c9-6cc3-44d2-bc6b-4cbf6ee6e30f} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 92.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38190) (comment: 02155_read_in_order_max_rows_to_read.sql) (query 11, line 21) (in query: SELECT a FROM t_max_rows_to_read WHERE a > 10 ORDER BY a LIMIT 5 FORMAT Null SETTINGS max_rows_to_read = 12;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000173d8103 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd21a90 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:08:11.773505 [ 1857 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 12.00, current rows: 92.00: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000173d8103 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd21a90 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:11.872603 [ 1857 ] {a1115b6d-aaff-4295-91b6-ad2ba11fe9c4} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 4.00, current rows: 12.00. (TOO_MANY_ROWS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38190) (comment: 02155_read_in_order_max_rows_to_read.sql) (query 12, line 22) (in query: SELECT a FROM t_max_rows_to_read WHERE a = 10 OR a = 20 FORMAT Null SETTINGS max_rows_to_read = 4;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001c39b250 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2115: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3bb0c2 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:08:11.873854 [ 1857 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 4.00, current rows: 12.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:325: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001c39b250 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2115: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3bb0c2 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:08:12.087091 [ 2114 ] {a505d034-c41f-4945-9974-8bd876f31fba} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38196) (comment: 02707_skip_index_with_in.sql) (query 5, line 18) (in query: EXPLAIN SELECT count() FROM t_skip_index_in WHERE c IN (SELECT throwIf(1)) SETTINGS use_skip_indexes = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 18. ./build_docker/./src/Interpreters/PreparedSets.cpp:270: DB::FutureSetFromSubquery::buildOrderedSetInplace(std::shared_ptr const&) @ 0x0000000018ab9b97 19. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:385: DB::MergeTreeIndexConditionBloomFilter::traverseFunction(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&, DB::RPNBuilderTreeNode const*) @ 0x000000001b4ba316 20. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:347: DB::MergeTreeIndexConditionBloomFilter::extractAtomFromTree(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x000000001b4ba095 21. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:194: bool std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::Block const&, unsigned long)::$_0, bool (DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&)>>(std::__function::__policy_storage const*, DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x000000001b4c1332 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b4c99f5 23. ./src/Storages/MergeTree/RPNBuilder.h:205: DB::MergeTreeIndexConditionBloomFilter::MergeTreeIndexConditionBloomFilter(DB::ActionsDAG::Node const*, std::shared_ptr, DB::Block const&, unsigned long) @ 0x000000001b4b8bd6 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeIndexBloomFilter::createIndexCondition(DB::ActionsDAG::Node const*, std::shared_ptr) const @ 0x000000001b4c0b48 25. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1665: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001c3b4ce5 26. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1702: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x000000001c3b38de 27. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000001c47d046 28. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:50: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000001c47ce57 29. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:125: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b075 30. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001c36ed72 31. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:523: DB::InterpreterExplainQuery::executeImpl() @ 0x00000000188f88de 2025.07.28 06:08:12.088517 [ 2114 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 18. ./build_docker/./src/Interpreters/PreparedSets.cpp:270: DB::FutureSetFromSubquery::buildOrderedSetInplace(std::shared_ptr const&) @ 0x0000000018ab9b97 19. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:385: DB::MergeTreeIndexConditionBloomFilter::traverseFunction(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&, DB::RPNBuilderTreeNode const*) @ 0x000000001b4ba316 20. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:347: DB::MergeTreeIndexConditionBloomFilter::extractAtomFromTree(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x000000001b4ba095 21. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:194: bool std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::Block const&, unsigned long)::$_0, bool (DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&)>>(std::__function::__policy_storage const*, DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x000000001b4c1332 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b4c99f5 23. ./src/Storages/MergeTree/RPNBuilder.h:205: DB::MergeTreeIndexConditionBloomFilter::MergeTreeIndexConditionBloomFilter(DB::ActionsDAG::Node const*, std::shared_ptr, DB::Block const&, unsigned long) @ 0x000000001b4b8bd6 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeIndexBloomFilter::createIndexCondition(DB::ActionsDAG::Node const*, std::shared_ptr) const @ 0x000000001b4c0b48 25. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1665: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001c3b4ce5 26. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1702: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x000000001c3b38de 27. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000001c47d046 28. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:50: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000001c47ce57 29. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:125: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b075 30. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001c36ed72 31. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:523: DB::InterpreterExplainQuery::executeImpl() @ 0x00000000188f88de 2025.07.28 06:08:12.256764 [ 1857 ] {c2229aaf-c996-4af1-85c4-b80976ccd0ec} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 07-08-2019: Cannot parse Date from String: In scope SELECT toDate('07-08-2019'). (CANNOT_PARSE_DATE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38212) (comment: 01933_invalid_date.sql) (query 1, line 1) (in query: SELECT toDate('07-08-2019');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./src/IO/ReadHelpers.h:762: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000014064fa2 5. ./src/IO/ReadHelpers.h:850: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c3eb5 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:08:12.258948 [ 1857 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 07-08-2019: Cannot parse Date from String: In scope SELECT toDate('07-08-2019'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./src/IO/ReadHelpers.h:762: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000014064fa2 5. ./src/IO/ReadHelpers.h:850: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c3eb5 6. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 7. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:08:12.335012 [ 1851 ] {c158b4d4-a0af-4cb0-a071-89fd316ccfb0} executeQuery: Code: 43. DB::Exception: Nested type Tuple() cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38202) (comment: 02891_empty_tuple.sql) (query 9, line 17) (in query: CREATE TABLE x (`i` Nullable(Tuple)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 18830, min_bytes_for_wide_part = 764991028, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 4, min_bytes_for_full_part_storage = 27460451, compact_parts_max_bytes_to_buffer = 19642871, compact_parts_max_granules_to_buffer = 9, compact_parts_merge_max_bytes_to_prefetch_part = 31207474, merge_max_block_size = 24302, old_parts_lifetime = 189., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 47, min_merge_bytes_to_use_direct_io = 2949739969, index_granularity_bytes = 30217420, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 10, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 49977, primary_key_compress_block_size = 62158, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x0000000017444bdb 5. std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr&) @ 0x00000000088149c6 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(std::shared_ptr const&) @ 0x0000000017445ecd 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 9. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:08:12.336911 [ 1851 ] {} TCPHandler: Code: 43. DB::Exception: Nested type Tuple() cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x0000000017444bdb 5. std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr&) @ 0x00000000088149c6 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(std::shared_ptr const&) @ 0x0000000017445ecd 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 9. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:08:12.456517 [ 419 ] {b7f207f2-fa12-45a4-95cd-71d6cdf25248} executeQuery: Code: 36. DB::Exception: Second argument to substringIndexUTF8 must be a single UTF-8 character: In scope SELECT substringIndexUTF8('富强,民主,文明', ',,', 2). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38164) (comment: 02798_substring_index.sql) (query 78, line 89) (in query: select substringIndexUTF8('富强,民主,文明', ',,', 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ecdbc95 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:08:12.458169 [ 419 ] {} TCPHandler: Code: 36. DB::Exception: Second argument to substringIndexUTF8 must be a single UTF-8 character: In scope SELECT substringIndexUTF8('富强,民主,文明', ',,', 2). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ecdbc95 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:08:12.466376 [ 419 ] {c9fa4b38-4391-4b92-b9f1-4ea4b7ac5f21} executeQuery: Code: 36. DB::Exception: Second argument to substringIndexUTF8 must be a single UTF-8 character: In scope SELECT substringIndexUTF8('富强,民主,文明', '', 2). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38164) (comment: 02798_substring_index.sql) (query 79, line 90) (in query: select substringIndexUTF8('富强,民主,文明', '', 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ecdbc95 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:08:12.467389 [ 419 ] {} TCPHandler: Code: 36. DB::Exception: Second argument to substringIndexUTF8 must be a single UTF-8 character: In scope SELECT substringIndexUTF8('富强,民主,文明', '', 2). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionSubstringIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ecdbc95 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:08:12.475543 [ 419 ] {892d084a-c49a-456d-89f6-5ff07e99a3a2} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function substringIndexUTF8 must be constant. (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38164) (comment: 02798_substring_index.sql) (query 80, line 91) (in query: select substringIndexUTF8('富强,民主,文明', materialize(','), 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ac8c7a6 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f13d97 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 13. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 14. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:08:12.476289 [ 419 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function substringIndexUTF8 must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ac8c7a6 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f13d97 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 13. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 14. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:08:12.476418 [ 1857 ] {de2d0ef1-b06c-41ea-9c18-21de5b4cbb45} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT toDate('2019-0708'). (CANNOT_PARSE_DATE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38212) (comment: 01933_invalid_date.sql) (query 2, line 2) (in query: SELECT toDate('2019-0708');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/IO/ReadHelpers.cpp:1389: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000010c4baef 5. ./build_docker/./src/IO/ReadHelpers.cpp:1444: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000010c4b857 6. ./src/IO/ReadHelpers.h:829: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000014064d3a 7. ./src/IO/ReadHelpers.h:850: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c3eb5 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 2025.07.28 06:08:12.477920 [ 1857 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT toDate('2019-0708'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/IO/ReadHelpers.cpp:1389: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000010c4baef 5. ./build_docker/./src/IO/ReadHelpers.cpp:1444: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000010c4b857 6. ./src/IO/ReadHelpers.h:829: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000014064d3a 7. ./src/IO/ReadHelpers.h:850: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c3eb5 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 2025.07.28 06:08:12.488417 [ 1851 ] {707a598f-cd28-4299-be9b-a489bf809cf2} executeQuery: Code: 43. DB::Exception: DataTypeLowCardinality is supported only for numbers, strings, Date or DateTime, but got Tuple(). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38202) (comment: 02891_empty_tuple.sql) (query 10, line 18) (in query: CREATE TABLE x (`i` LowCardinality(Tuple)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 18830, min_bytes_for_wide_part = 764991028, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 4, min_bytes_for_full_part_storage = 27460451, compact_parts_max_bytes_to_buffer = 19642871, compact_parts_max_granules_to_buffer = 9, compact_parts_merge_max_bytes_to_prefetch_part = 31207474, merge_max_block_size = 24302, old_parts_lifetime = 189., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 47, min_merge_bytes_to_use_direct_io = 2949739969, index_granularity_bytes = 30217420, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 10, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 49977, primary_key_compress_block_size = 62158, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/DataTypes/DataTypeLowCardinality.cpp:38: DB::DataTypeLowCardinality::DataTypeLowCardinality(std::shared_ptr) @ 0x0000000017439212 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, 0>(std::allocator const&, std::shared_ptr&&) @ 0x0000000010e73b74 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(std::shared_ptr const&) @ 0x000000001743b22d 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 9. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:08:12.490070 [ 1851 ] {} TCPHandler: Code: 43. DB::Exception: DataTypeLowCardinality is supported only for numbers, strings, Date or DateTime, but got Tuple(). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/DataTypes/DataTypeLowCardinality.cpp:38: DB::DataTypeLowCardinality::DataTypeLowCardinality(std::shared_ptr) @ 0x0000000017439212 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, 0>(std::allocator const&, std::shared_ptr&&) @ 0x0000000010e73b74 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(std::shared_ptr const&) @ 0x000000001743b22d 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 9. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:08:12.614657 [ 419 ] {58dbc383-e8b9-427c-bc40-05fb85c9d3ec} executeQuery: Code: 43. DB::Exception: Illegal type Int128 of third argument of function substringIndexUTF8, Integer expected: In scope SELECT substringIndexUTF8('富强,民主,文明', ',', CAST(2, 'Int128')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38164) (comment: 02798_substring_index.sql) (query 81, line 92) (in query: select substringIndexUTF8('富强,民主,文明', ',', cast(2 as Int128));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::(anonymous namespace)::FunctionSubstringIndex::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ecdc393 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:08:12.616407 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int128 of third argument of function substringIndexUTF8, Integer expected: In scope SELECT substringIndexUTF8('富强,民主,文明', ',', CAST(2, 'Int128')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::(anonymous namespace)::FunctionSubstringIndex::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ecdc393 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:08:12.672158 [ 1857 ] {ea919825-0f85-4c31-b891-b3052a47fb7d} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT toDate('201907-08'). (CANNOT_PARSE_DATE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38212) (comment: 01933_invalid_date.sql) (query 3, line 3) (in query: SELECT toDate('201907-08');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/IO/ReadHelpers.cpp:1389: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000010c4baef 5. ./build_docker/./src/IO/ReadHelpers.cpp:1424: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000010c4b796 6. ./src/IO/ReadHelpers.h:829: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000014064d3a 7. ./src/IO/ReadHelpers.h:850: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c3eb5 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 2025.07.28 06:08:12.675298 [ 1857 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT toDate('201907-08'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/IO/ReadHelpers.cpp:1389: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000010c4baef 5. ./build_docker/./src/IO/ReadHelpers.cpp:1424: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000010c4b796 6. ./src/IO/ReadHelpers.h:829: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000014064d3a 7. ./src/IO/ReadHelpers.h:850: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c3eb5 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 2025.07.28 06:08:13.399883 [ 1857 ] {d93efaae-2073-4e99-a3d6-11bf5811a30e} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 07-08-2019: while converting '07-08-2019' to Date. (CANNOT_PARSE_DATE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38212) (comment: 01933_invalid_date.sql) (query 7, line 9) (in query: SELECT * FROM test WHERE d >= '07-08-2019';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./src/IO/ReadHelpers.h:762: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000014064fa2 5. ./src/IO/ReadHelpers.h:850: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001752b170 6. ./build_docker/./src/DataTypes/Serializations/SerializationDate.cpp:20: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001752b055 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd6adf 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b1e0450 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b1cad65 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 18. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000001c0b4ee0 19. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000001c321a81 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000001895e815 21. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898e9cd 22. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x00000000189866e7 23. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:08:13.404549 [ 1857 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 07-08-2019: while converting '07-08-2019' to Date. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./src/IO/ReadHelpers.h:762: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000014064fa2 5. ./src/IO/ReadHelpers.h:850: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001752b170 6. ./build_docker/./src/DataTypes/Serializations/SerializationDate.cpp:20: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001752b055 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd6adf 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b1e0450 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b1cad65 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 18. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000001c0b4ee0 19. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000001c321a81 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000001895e815 21. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898e9cd 22. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x00000000189866e7 23. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:08:18.419867 [ 1860 ] {b44f12f8-d976-450b-9cc2-57edf0479d1e} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `value` in scope SELECT sum(value) FROM test_alter_on_mutation. Maybe you meant: ['value1']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38254) (comment: 01062_alter_on_mutataion_zookeeper_long.sql) (query 21, line 48) (in query: SELECT sum(value) from test_alter_on_mutation;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:08:18.421310 [ 1860 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `value` in scope SELECT sum(value) FROM test_alter_on_mutation. Maybe you meant: ['value1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:08:19.527510 [ 1212 ] {0c2cc6fc-a6ed-4e0f-b3bf-2b6928aaa3bf} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000000 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:08:19.528999 [ 1212 ] {0c2cc6fc-a6ed-4e0f-b3bf-2b6928aaa3bf} DDLWorker: Query /* ddl_entry=query-0000000000 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:08:20.002605 [ 2095 ] {dcc6b615-a1fd-4693-ac42-114f7550abee} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48600) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_bjvtwt86.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:20.042631 [ 2095 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:20.764829 [ 1212 ] {2bfb9e03-1488-48ac-8bbc-8e184c657338} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000001 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:08:20.765785 [ 1212 ] {2bfb9e03-1488-48ac-8bbc-8e184c657338} DDLWorker: Query /* ddl_entry=query-0000000001 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:08:20.793056 [ 2062 ] {2e3dd204-e6bc-462c-8b48-9fbabacc7ea4} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48684) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_bjvtwt86.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:20.795267 [ 2062 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:22.345318 [ 1212 ] {308a6e7a-7fb6-48d5-93f8-516e57fb0cb2} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000003 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:08:22.346054 [ 1212 ] {308a6e7a-7fb6-48d5-93f8-516e57fb0cb2} DDLWorker: Query /* ddl_entry=query-0000000003 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:08:22.413943 [ 419 ] {2e1ca22e-9458-4222-9875-fc1f992bf1bd} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48776) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_bjvtwt86.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:22.415914 [ 419 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:23.939743 [ 1212 ] {1c896d02-94cc-4c04-94b7-f437cdf089dd} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000005 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:08:23.945736 [ 1212 ] {1c896d02-94cc-4c04-94b7-f437cdf089dd} DDLWorker: Query /* ddl_entry=query-0000000005 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:08:23.993802 [ 1861 ] {66cbf495-c9fb-4722-b752-cc2840fae160} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48870) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_bjvtwt86.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:24.013019 [ 1861 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:25.022601 [ 419 ] {9705ec7b-b619-4dba-bce8-a6f346e2c29f} executeQuery: Code: 70. DB::Exception: Cannot convert type UInt32 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT CAST(CAST('42', 'UInt32'), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48826) (comment: 02942_variant_cast.sql) (query 4, line 5) (in query: select 42::UInt32::Variant(String, UInt64);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x0000000015fd2764 5. DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc7988 6. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5cd8 7. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3558: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa70a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:08:25.027312 [ 419 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert type UInt32 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT CAST(CAST('42', 'UInt32'), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x0000000015fd2764 5. DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc7988 6. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5cd8 7. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3558: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa70a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:08:25.046583 [ 419 ] {454e6dc8-5cd9-4b81-9c9a-40272bcabdc9} executeQuery: Code: 70. DB::Exception: Cannot convert type DateTime to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT CAST(now(), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48826) (comment: 02942_variant_cast.sql) (query 5, line 6) (in query: select now()::Variant(String, UInt64);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x0000000015fd2764 5. DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc7988 6. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5cd8 7. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3558: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa70a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:08:25.047429 [ 419 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert type DateTime to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT CAST(now(), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x0000000015fd2764 5. DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc7988 6. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5cd8 7. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3558: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa70a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:08:25.422180 [ 1212 ] {a3895175-2746-4071-bfab-1c25f376dbf6} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000007 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:08:25.423185 [ 1212 ] {a3895175-2746-4071-bfab-1c25f376dbf6} DDLWorker: Query /* ddl_entry=query-0000000007 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:08:25.455516 [ 1861 ] {a1d43181-dc09-46fb-b04f-d3ffbd76923d} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48928) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_bjvtwt86.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:25.460551 [ 1861 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:25.969462 [ 419 ] {b8ee8343-8b6c-4c46-a049-82d01d76b8ab} executeQuery: Code: 6. DB::Exception: Cannot parse string 'str' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST(CAST('str', 'Variant(String, UInt64)'), 'UInt64'). (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48826) (comment: 02942_variant_cast.sql) (query 15, line 17) (in query: select 'str'::Variant(String, UInt64)::UInt64;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::FunctionCast::createVariantToColumnWrapper(DB::DataTypeVariant const&, std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000015fde14e 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015fddcea 17. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 18. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 20. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 22. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 23. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 31. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 2025.07.28 06:08:25.979379 [ 419 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'str' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST(CAST('str', 'Variant(String, UInt64)'), 'UInt64'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::FunctionCast::createVariantToColumnWrapper(DB::DataTypeVariant const&, std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000015fde14e 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015fddcea 17. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 18. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 20. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 22. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 23. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 31. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 2025.07.28 06:08:25.986463 [ 2055 ] {c87a3046-af93-4084-954e-8101d5f8cd2d} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48892) (comment: 01710_projections.sql) (query 5, line 9) (in query: select * from projection_test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47becc 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:08:25.987501 [ 2055 ] {} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47becc 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:08:26.057133 [ 2055 ] {a570a84c-e2ca-450c-9d1b-99cd96bf2834} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48892) (comment: 01710_projections.sql) (query 6, line 10) (in query: select toStartOfMinute(datetime) dt_m, countIf(first_time = 0) from projection_test join (select 1) x on 1 where domain = '1' group by dt_m order by dt_m;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47becc 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:08:26.063084 [ 2055 ] {} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47becc 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:08:26.393600 [ 419 ] {0b2d0139-5a08-45e5-a955-0c057aaf0c49} executeQuery: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(multiIf(equals(__table1.number, 1_UInt8), _CAST(NULL_Variant(String, UInt64), 'Variant(String, UInt64)'_String), equals(__table1.number, 2_UInt8), _CAST('Hello'_Variant(String, UInt64), 'Variant(String, UInt64)'_String), CAST(__table1.number, 'Variant(String, UInt64)'_String)) :: 5, 'UInt64'_String :: 6) -> CAST(multiIf(equals(__table1.number, 1_UInt8), _CAST(NULL_Variant(String, UInt64), 'Variant(String, UInt64)'_String), equals(__table1.number, 2_UInt8), _CAST('Hello'_Variant(String, UInt64), 'Variant(String, UInt64)'_String), CAST(__table1.number, 'Variant(String, UInt64)'_String)), 'UInt64'_String) UInt64 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48826) (comment: 02942_variant_cast.sql) (query 17, line 19) (in query: select CAST(multiIf(number == 1, NULL::Variant(String, UInt64), number == 2, 'Hello'::Variant(String, UInt64), number::Variant(String, UInt64)), 'UInt64') from numbers(6);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::FunctionCast::createVariantToColumnWrapper(DB::DataTypeVariant const&, std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000015fde14e 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015fddcea 17. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 2025.07.28 06:08:26.406563 [ 419 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(multiIf(equals(__table1.number, 1_UInt8), _CAST(NULL_Variant(String, UInt64), 'Variant(String, UInt64)'_String), equals(__table1.number, 2_UInt8), _CAST('Hello'_Variant(String, UInt64), 'Variant(String, UInt64)'_String), CAST(__table1.number, 'Variant(String, UInt64)'_String)) :: 5, 'UInt64'_String :: 6) -> CAST(multiIf(equals(__table1.number, 1_UInt8), _CAST(NULL_Variant(String, UInt64), 'Variant(String, UInt64)'_String), equals(__table1.number, 2_UInt8), _CAST('Hello'_Variant(String, UInt64), 'Variant(String, UInt64)'_String), CAST(__table1.number, 'Variant(String, UInt64)'_String)), 'UInt64'_String) UInt64 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::FunctionCast::createVariantToColumnWrapper(DB::DataTypeVariant const&, std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000015fde14e 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015fddcea 17. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:26.569131 [ 419 ] {ebddc44d-9a91-4367-a851-532a2e3e76ea} executeQuery: Code: 70. DB::Exception: Cannot convert type Variant(String, UInt64) to Variant(Array(UInt64), String). Conversion between Variant types is allowed only when new Variant type is an extension of an initial one: In scope SELECT CAST(CAST('str', 'Variant(String, UInt64)'), 'Variant(String, Array(UInt64))'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48826) (comment: 02942_variant_cast.sql) (query 19, line 23) (in query: select 'str'::Variant(String, UInt64)::Variant(String, Array(UInt64));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::detail::FunctionCast::createVariantToVariantWrapper(DB::DataTypeVariant const&, DB::DataTypeVariant const&) const @ 0x0000000015fd3a2b 5. DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc795f 6. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5cd8 7. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3558: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa70a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:08:26.570504 [ 419 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert type Variant(String, UInt64) to Variant(Array(UInt64), String). Conversion between Variant types is allowed only when new Variant type is an extension of an initial one: In scope SELECT CAST(CAST('str', 'Variant(String, UInt64)'), 'Variant(String, Array(UInt64))'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::detail::FunctionCast::createVariantToVariantWrapper(DB::DataTypeVariant const&, DB::DataTypeVariant const&) const @ 0x0000000015fd3a2b 5. DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc795f 6. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5cd8 7. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3558: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa70a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:08:28.030934 [ 1212 ] {c4dfcb35-3e74-4789-bd77-b457788a684b} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000010 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:08:28.038781 [ 1212 ] {c4dfcb35-3e74-4789-bd77-b457788a684b} DDLWorker: Query /* ddl_entry=query-0000000010 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:08:28.080669 [ 2060 ] {a1e6bd23-8071-4a9d-a694-5334ceb28737} executeQuery: Code: 80. DB::Exception: There are no columns in sampling expression. (INCORRECT_QUERY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41446) (comment: 02096_sample_by_tuple.sql) (query 2, line 3) (in query: CREATE TABLE t (`n` UInt8) ENGINE = MergeTree ORDER BY n SAMPLE BY tuple() SETTINGS index_granularity = 14050, min_bytes_for_wide_part = 69223897, ratio_of_defaults_for_sparse_serialization = 0.7063431739807129, replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 64206169, compact_parts_max_granules_to_buffer = 160, compact_parts_merge_max_bytes_to_prefetch_part = 17858402, merge_max_block_size = 20675, old_parts_lifetime = 149., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10447312346, index_granularity_bytes = 18558941, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 62, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41508, primary_key_compress_block_size = 85758, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:316: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x000000001b2e33b4 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:523: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e04c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:08:28.094713 [ 2095 ] {efdccedd-b450-4dde-9127-a41bc9018567} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41488) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_bjvtwt86.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:28.116792 [ 2060 ] {} TCPHandler: Code: 80. DB::Exception: There are no columns in sampling expression. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:316: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x000000001b2e33b4 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:523: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e04c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:08:28.121287 [ 2095 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:28.332089 [ 2060 ] {854bbd50-33cc-49a1-af6b-aa69a98200a4} executeQuery: Code: 80. DB::Exception: There are no columns in sampling expression. (INCORRECT_QUERY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41446) (comment: 02096_sample_by_tuple.sql) (query 4, line 7) (in query: ALTER TABLE t MODIFY SAMPLE BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:316: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x000000001b2e33b4 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3713: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b327328 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:08:28.347325 [ 2060 ] {} TCPHandler: Code: 80. DB::Exception: There are no columns in sampling expression. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:316: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x000000001b2e33b4 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3713: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b327328 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:08:29.707875 [ 1212 ] {446f0309-9c54-4c6e-a428-e39d5a78e373} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000012 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:08:29.710730 [ 1212 ] {446f0309-9c54-4c6e-a428-e39d5a78e373} DDLWorker: Query /* ddl_entry=query-0000000012 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:08:29.760757 [ 2064 ] {cd892cdf-9558-4246-acc4-71509baae681} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41578) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_bjvtwt86.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:29.762769 [ 2064 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:32.829213 [ 1212 ] {d4893cac-f13e-4678-8133-678c9c3ac7ec} executeQuery: Code: 341. DB::Exception: Some replicas doesn't finish metadata alter: Log entry log-0000000000 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000013 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000087ec0e6 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7182: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x000000001ad09411 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6707: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad118b1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x00000000182b257c 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abf49 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:08:32.851210 [ 1212 ] {d4893cac-f13e-4678-8133-678c9c3ac7ec} DDLWorker: Query /* ddl_entry=query-0000000013 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 341. DB::Exception: Some replicas doesn't finish metadata alter: Log entry log-0000000000 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000087ec0e6 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7182: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x000000001ad09411 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6707: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad118b1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x00000000182b257c 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abf49 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:08:33.143901 [ 1212 ] {} DDLWorker: , task query-0000000013 will not be executed. 2025.07.28 06:08:33.359448 [ 2062 ] {0a0cf958-7020-4636-a640-bab73a8372ff} executeQuery: Code: 341. DB::Exception: There was an error on [localhost:9000]: Cannot execute replicated DDL query, table is dropped or detached permanently. (UNFINISHED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41610) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_bjvtwt86.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:33.408093 [ 2062 ] {} TCPHandler: Code: 341. DB::Exception: There was an error on [localhost:9000]: Cannot execute replicated DDL query, table is dropped or detached permanently. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:33.939294 [ 1867 ] {d0330372-d3a3-4771-9d03-66afb7f2468d} executeQuery: Code: 70. DB::Exception: Conversion from IntervalDay to Decimal(10, 10) is not supported: In scope SELECT CAST(toIntervalDay(1), 'Nullable(Decimal(10, 10))'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41710) (comment: 00879_cast_to_decimal_crash.sql) (query 1, line 1) (in query: select cast(toIntervalDay(1) as Nullable(Decimal(10, 10)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const @ 0x00000000160f0937 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fe074f 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fc7a8d 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5ed8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3558: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa70a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:08:33.940753 [ 1867 ] {} TCPHandler: Code: 70. DB::Exception: Conversion from IntervalDay to Decimal(10, 10) is not supported: In scope SELECT CAST(toIntervalDay(1), 'Nullable(Decimal(10, 10))'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const @ 0x00000000160f0937 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fe074f 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fc7a8d 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5ed8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3558: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa70a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:08:33.971602 [ 1212 ] {92eb5c95-2a98-49db-829d-155d7a57f0e6} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000014 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:08:33.972456 [ 1212 ] {92eb5c95-2a98-49db-829d-155d7a57f0e6} DDLWorker: Query /* ddl_entry=query-0000000014 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:08:34.036058 [ 419 ] {89f36df9-5a81-4982-b755-18643f38058b} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41744) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_bjvtwt86.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:34.041149 [ 419 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:35.823237 [ 1212 ] {e4f8ac3d-251b-49e9-bdeb-4a95280d9f41} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000016 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:08:35.840434 [ 1212 ] {e4f8ac3d-251b-49e9-bdeb-4a95280d9f41} DDLWorker: Query /* ddl_entry=query-0000000016 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0bcc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:08:35.951029 [ 2060 ] {96603d8f-c84c-4932-b6f8-da9cfa3c6efe} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41822) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_bjvtwt86.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:35.970966 [ 2060 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:08:37.886553 [ 1212 ] {74c17116-196e-4692-9c47-ca03e801c1a3} executeQuery: Code: 341. DB::Exception: Some replicas doesn't finish metadata alter: Log entry log-0000000000 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000017 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000087ec0e6 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7182: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x000000001ad09411 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6707: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad118b1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x00000000182b257c 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abf49 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:08:37.887609 [ 1212 ] {74c17116-196e-4692-9c47-ca03e801c1a3} DDLWorker: Query /* ddl_entry=query-0000000017 */ ALTER TABLE test_bjvtwt86.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 341. DB::Exception: Some replicas doesn't finish metadata alter: Log entry log-0000000000 is not precessed on local replica, most likely because the replica was shut down. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000087ec0e6 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7182: DB::StorageReplicatedMergeTree::waitForLogEntryToBeProcessedIfNecessary(DB::ReplicatedMergeTreeLogEntryData const&, std::shared_ptr, String const&) @ 0x000000001ad09411 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6707: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad118b1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x00000000182b257c 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abf49 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:08:38.893805 [ 1212 ] {} DDLWorker: , task query-0000000017 will not be executed. 2025.07.28 06:08:40.229814 [ 2061 ] {00a701cb-03b6-432a-a6c7-cbed59f6736f} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41854) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_bjvtwt86.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000001bc0554f 3. ./build_docker/./src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001bbfc176 4. ./build_docker/./src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebcbe 5. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:08:40.426699 [ 2061 ] {00a701cb-03b6-432a-a6c7-cbed59f6736f} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41854). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d883af 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2558: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000001bbe8f95 7. ./build_docker/./src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x000000001bbdaef1 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:08:40.483503 [ 2061 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000001bc0554f 3. ./build_docker/./src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001bbfc176 4. ./build_docker/./src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebcbe 5. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:08:43.274648 [ 1859 ] {486143a8-3aa1-4026-9b27-6c1750245823} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 0, should be 2: In scope SELECT changeYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43612) (comment: 02982_changeDate.sql) (query 2, line 2) (in query: -- as changeYear, changeMonth, changeDay, changeMinute, changeSecond share the same implementation, just testing one of them SELECT changeYear();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:08:43.293038 [ 1859 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 0, should be 2: In scope SELECT changeYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:08:43.310892 [ 1859 ] {bbb1bfb2-abe4-4ed3-8a05-5607b283226c} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 1, should be 2: In scope SELECT changeYear(toDate('2000-01-01')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43612) (comment: 02982_changeDate.sql) (query 3, line 4) (in query: SELECT changeYear(toDate('2000-01-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:08:43.314079 [ 1859 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 1, should be 2: In scope SELECT changeYear(toDate('2000-01-01')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:08:43.342463 [ 1859 ] {6789513d-54b8-4e9c-84f0-b9c9e60066fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(toDate('2000-01-01'), 2000, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43612) (comment: 02982_changeDate.sql) (query 4, line 5) (in query: SELECT changeYear(toDate('2000-01-01'), 2000, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:08:43.344738 [ 1859 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(toDate('2000-01-01'), 2000, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:08:43.593597 [ 1859 ] {4af5495e-c8b7-4fb8-b7fc-db9ad618e97b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeYear'. Expected: Date or date with time, got: UInt16: In scope SELECT changeYear(1999, 2000). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43612) (comment: 02982_changeDate.sql) (query 5, line 6) (in query: SELECT changeYear(1999, 2000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionChangeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0d8324 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:08:43.597877 [ 1859 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeYear'. Expected: Date or date with time, got: UInt16: In scope SELECT changeYear(1999, 2000). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionChangeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0d8324 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:08:43.609967 [ 1859 ] {8f0c2768-19dd-49f4-81bc-d3c856fbce78} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'value' to function 'changeYear'. Expected: Integer, got: String: In scope SELECT changeYear(toDate('2000-01-01'), 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43612) (comment: 02982_changeDate.sql) (query 6, line 7) (in query: SELECT changeYear(toDate('2000-01-01'), 'abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionChangeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0d8324 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:08:43.612158 [ 1859 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'value' to function 'changeYear'. Expected: Integer, got: String: In scope SELECT changeYear(toDate('2000-01-01'), 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionChangeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0d8324 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:08:43.626563 [ 1859 ] {6057d946-0f2a-4aea-91ea-edaa9069e7cf} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'value' to function 'changeYear'. Expected: Integer, got: Float64: In scope SELECT changeYear(toDate('2000-01-01'), 1.5). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43612) (comment: 02982_changeDate.sql) (query 7, line 8) (in query: SELECT changeYear(toDate('2000-01-01'), 1.5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionChangeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0d8324 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:08:43.627600 [ 1859 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'value' to function 'changeYear'. Expected: Integer, got: Float64: In scope SELECT changeYear(toDate('2000-01-01'), 1.5). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionChangeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0d8324 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:08:54.880761 [ 1212 ] {c1b9fbc9-6953-481d-8b9e-f4c7d4829d2b} executeQuery: Code: 57. DB::Exception: Table test_b6gg2b3v.none already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_b6gg2b3v) (in query: /* ddl_entry=query-0000000019 */ CREATE TABLE test_b6gg2b3v.none UUID 'f18448d9-84e7-4488-9b09-a8ad42194372' (`n` Int32) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d01e6 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:08:54.902950 [ 1212 ] {c1b9fbc9-6953-481d-8b9e-f4c7d4829d2b} DDLWorker: Query /* ddl_entry=query-0000000019 */ CREATE TABLE test_b6gg2b3v.none UUID 'f18448d9-84e7-4488-9b09-a8ad42194372' (`n` Int32) ENGINE = Memory wasn't finished successfully: Code: 57. DB::Exception: Table test_b6gg2b3v.none already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d01e6 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:08:55.153730 [ 2055 ] {0ce529f3-41ba-4789-95f6-7bb7943a5f85} executeQuery: Code: 57. DB::Exception: There was an error on [localhost:9000]: Code: 57. DB::Exception: Table test_b6gg2b3v.none already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)). (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39068) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_b6gg2b3v) (query 1, line 1) (in query: create table none on cluster test_shard_localhost (n int) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:55.164856 [ 2055 ] {} TCPHandler: Code: 57. DB::Exception: There was an error on [localhost:9000]: Code: 57. DB::Exception: Table test_b6gg2b3v.none already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:08:57.002766 [ 2060 ] {a6feb5bd-0990-48ab-b827-e9999d14d6b8} executeQuery: Code: 159. DB::Exception: Distributed DDL task /clickhouse/task_queue/ddl/query-0000000020 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 1.139999637 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39136) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_b6gg2b3v) (query 1, line 1) (in query: drop table if exists none on cluster test_unavailable_shard;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x0000000018ae4985 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:84: DB::DDLOnClusterQueryStatusSource::handleTimeoutExceeded() @ 0x0000000018e04906 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f7373 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:57.033487 [ 2060 ] {} TCPHandler: Code: 159. DB::Exception: Distributed DDL task /clickhouse/task_queue/ddl/query-0000000020 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 1.139999637 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x0000000018ae4985 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:84: DB::DDLOnClusterQueryStatusSource::handleTimeoutExceeded() @ 0x0000000018e04906 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f7373 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:08:59.310748 [ 1212 ] {aa8658d4-4023-4985-839a-8fb868f493d0} executeQuery: Code: 57. DB::Exception: Table test_b6gg2b3v.throw already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_b6gg2b3v) (in query: /* ddl_entry=query-0000000022 */ CREATE TABLE test_b6gg2b3v.throw UUID 'a9b055f2-6a08-463b-8744-32ff40e99b41' (`n` Int32) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d01e6 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:08:59.312193 [ 1212 ] {aa8658d4-4023-4985-839a-8fb868f493d0} DDLWorker: Query /* ddl_entry=query-0000000022 */ CREATE TABLE test_b6gg2b3v.throw UUID 'a9b055f2-6a08-463b-8744-32ff40e99b41' (`n` Int32) ENGINE = Memory wasn't finished successfully: Code: 57. DB::Exception: Table test_b6gg2b3v.throw already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d01e6 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:08:59.340031 [ 1808 ] {971dcbad-c03c-452f-97d2-f259022452c0} executeQuery: Code: 57. DB::Exception: There was an error on [localhost:9000]: Code: 57. DB::Exception: Table test_b6gg2b3v.throw already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)). (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52478) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_b6gg2b3v) (query 1, line 1) (in query: create table throw on cluster test_shard_localhost (n int) engine=Memory format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:08:59.341283 [ 1808 ] {} TCPHandler: Code: 57. DB::Exception: There was an error on [localhost:9000]: Code: 57. DB::Exception: Table test_b6gg2b3v.throw already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:09:02.530469 [ 1865 ] {0153c271-17d0-4a62-b4ee-f4d8c60043f3} executeQuery: Code: 159. DB::Exception: Distributed DDL task /clickhouse/task_queue/ddl/query-0000000023 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 1.171999618 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52496) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_b6gg2b3v) (query 1, line 1) (in query: drop table if exists throw on cluster test_unavailable_shard;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x0000000018ae4985 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:84: DB::DDLOnClusterQueryStatusSource::handleTimeoutExceeded() @ 0x0000000018e04906 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f7373 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:09:02.550477 [ 1865 ] {} TCPHandler: Code: 159. DB::Exception: Distributed DDL task /clickhouse/task_queue/ddl/query-0000000023 is not finished on 1 of 2 hosts (0 of them are currently executing the task, 0 are inactive). They are going to execute the query in background. Was waiting for 1.171999618 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x0000000018ae4985 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:84: DB::DDLOnClusterQueryStatusSource::handleTimeoutExceeded() @ 0x0000000018e04906 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f7373 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:09:04.870969 [ 1212 ] {cdd08995-a95e-4819-986a-20407f552f43} executeQuery: Code: 57. DB::Exception: Table test_b6gg2b3v.null_status already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_b6gg2b3v) (in query: /* ddl_entry=query-0000000025 */ CREATE TABLE test_b6gg2b3v.null_status UUID '2f1e4fae-412c-474d-bf3e-c62357da4cc5' (`n` Int32) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d01e6 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:09:04.872100 [ 1212 ] {cdd08995-a95e-4819-986a-20407f552f43} DDLWorker: Query /* ddl_entry=query-0000000025 */ CREATE TABLE test_b6gg2b3v.null_status UUID '2f1e4fae-412c-474d-bf3e-c62357da4cc5' (`n` Int32) ENGINE = Memory wasn't finished successfully: Code: 57. DB::Exception: Table test_b6gg2b3v.null_status already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d01e6 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:09:04.913444 [ 1859 ] {1396e959-7869-4ab1-b09f-a3fa93d54859} executeQuery: Code: 57. DB::Exception: There was an error on [localhost:9000]: Code: 57. DB::Exception: Table test_b6gg2b3v.null_status already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)). (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52720) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_b6gg2b3v) (query 1, line 1) (in query: create table null_status on cluster test_shard_localhost (n int) engine=Memory format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:09:04.916329 [ 1859 ] {} TCPHandler: Code: 57. DB::Exception: There was an error on [localhost:9000]: Code: 57. DB::Exception: Table test_b6gg2b3v.null_status already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000018e05a4c 4. ./build_docker/./src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000018e05406 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f6e3a 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:09:09.064568 [ 1212 ] {906cc195-e458-449e-a6ef-8754872008a9} executeQuery: Code: 57. DB::Exception: Table test_b6gg2b3v.never_throw already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01175_distributed_ddl_output_mode_long.sh_01175_DDL_test_b6gg2b3v) (in query: /* ddl_entry=query-0000000028 */ CREATE TABLE test_b6gg2b3v.never_throw UUID 'f8b880aa-681d-49cc-9cca-dc06396e97a2' (`n` Int32) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d01e6 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:09:09.065180 [ 1212 ] {906cc195-e458-449e-a6ef-8754872008a9} DDLWorker: Query /* ddl_entry=query-0000000028 */ CREATE TABLE test_b6gg2b3v.never_throw UUID 'f8b880aa-681d-49cc-9cca-dc06396e97a2' (`n` Int32) ENGINE = Memory wasn't finished successfully: Code: 57. DB::Exception: Table test_b6gg2b3v.never_throw already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d01e6 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000182a8998 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000182a0242 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:09:09.939535 [ 2062 ] {8293d445-bd2d-4d95-bc4f-f2461cb1b1ac} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 46 (numbers): numbers. Expected one of: token, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49040) (comment: 00956_sensitive_data_masking.sh) (in query: SELECT 'find_me_[hidden]' FRRRROM numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:09:09.955988 [ 2062 ] {8293d445-bd2d-4d95-bc4f-f2461cb1b1ac} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 46 (numbers): numbers. Expected one of: token, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, ParallelWithClause, PARALLEL WITH, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:09:10.893269 [ 2062 ] {bb5a1e5c-571b-42fd-a249-dde299347325} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `credit_card_number` in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39884) (comment: 00956_sensitive_data_masking.sh) (query 1, line 1) (in query: SELECT 1 FROM system.numbers WHERE credit_card_number='find_me_[hidden]' FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5630: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7f0b0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:09:10.925728 [ 2062 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `credit_card_number` in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5630: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7f0b0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:09:11.148172 [ 419 ] {2cf89391-a04b-4801-8881-1ceedc30607f} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `credit_card_number` in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49046) (comment: 00956_sensitive_data_masking.sh) (in query: SELECT 1 FROM system.numbers WHERE credit_card_number='find_me_[hidden]' FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5630: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7f0b0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:09:11.166407 [ 419 ] {2cf89391-a04b-4801-8881-1ceedc30607f} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression or function identifier `credit_card_number` in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5630: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7f0b0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:09:13.491084 [ 1860 ] {bcac2dbf-f5ca-4568-b966-0dd13e979a5d} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION intDiv(100_UInt8 :: 1, minus(__table1.number, 10_UInt8) :: 0) -> intDiv(100_UInt8, minus(__table1.number, 10_UInt8)) Int8 : 2'. (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39960) (comment: 00956_sensitive_data_masking.sh) (query 1, line 1) (in query: SELECT 'find_me_[hidden]', intDiv( 100, number - 10) FROM numbers(11) FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::throwIfDivisionLeadsToFPE<_BitInt(8), long>(_BitInt(8), long) @ 0x000000000ac725f9 5. void DB::impl_::BinaryOperation, _BitInt(8)>::process<(DB::impl_::OpCase)1>(char8_t const*, long const*, DB::impl_::BinaryOperation, _BitInt(8)>*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000b9f0a7e 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc736b9 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc6d130 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc6b9ab 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc66e33 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc65846 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc6447e 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:09:13.506487 [ 1860 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION intDiv(100_UInt8 :: 1, minus(__table1.number, 10_UInt8) :: 0) -> intDiv(100_UInt8, minus(__table1.number, 10_UInt8)) Int8 : 2'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::throwIfDivisionLeadsToFPE<_BitInt(8), long>(_BitInt(8), long) @ 0x000000000ac725f9 5. void DB::impl_::BinaryOperation, _BitInt(8)>::process<(DB::impl_::OpCase)1>(char8_t const*, long const*, DB::impl_::BinaryOperation, _BitInt(8)>*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000b9f0a7e 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc736b9 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc6d130 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc6b9ab 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc66e33 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc65846 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc6447e 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:09:15.188701 [ 1867 ] {575a9c2c-6208-4334-b5df-accd94b52447} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40092) (comment: 00956_sensitive_data_masking.sh) (query 1, line 1) (in query: select sleepEachRow(1) from numbers(10) where ignore('find_me_[hidden]')=0 and ignore('fwerkh_that_magic_string_make_me_unique') = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:09:15.222529 [ 1867 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:09:38.784858 [ 1861 ] {9ca8b531-e096-4274-aaa5-30dd34806033} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 18.31 MiB (attempt to allocate chunk of 9.16 MiB bytes), maximum: 9.54 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41412) (comment: 01019_Buffer_and_max_memory_usage.sql) (query 11, line 33) (in query: INSERT INTO buffer_ SELECT toUInt64(number) FROM system.numbers LIMIT toUInt64(10e6+1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x0000000010ae15e4 9. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x000000001a6e8ac9 10. DB::IColumn::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x0000000015f1c159 11. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x0000000018b516ec 12. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x0000000018b50660 13. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000018923448 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 17. ./src/Processors/Transforms/ApplySquashingTransform.h:29: DB::ApplySquashingTransform::work() @ 0x00000000189231cb 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 22. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:09:38.798240 [ 1861 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 18.31 MiB (attempt to allocate chunk of 9.16 MiB bytes), maximum: 9.54 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x0000000010ae15e4 9. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x000000001a6e8ac9 10. DB::IColumn::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x0000000015f1c159 11. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x0000000018b516ec 12. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x0000000018b50660 13. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000018923448 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 17. ./src/Processors/Transforms/ApplySquashingTransform.h:29: DB::ApplySquashingTransform::work() @ 0x00000000189231cb 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 22. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:09:39.332883 [ 1855 ] {3638c49c-162a-4f04-9da4-6c5445dbb2b8} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_y9t1nf6z_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_y9t1nf6z.mv_test_03327. (ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41396) (comment: 03327_permissions_on_refresh_mv.sh) (query 2, line 3) (in query: system refresh view mv_test_03327;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d09340 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d078d1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000016d06c71 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000016cceb63 8. ./src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001819c9bc 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1382: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000018e5c6bf 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:720: DB::InterpreterSystemQuery::execute() @ 0x0000000018e53cfb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:09:39.333947 [ 1855 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_y9t1nf6z_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_y9t1nf6z.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d09340 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d078d1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000016d06c71 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000016cceb63 8. ./src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001819c9bc 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1382: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000018e5c6bf 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:720: DB::InterpreterSystemQuery::execute() @ 0x0000000018e53cfb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:09:39.512112 [ 1855 ] {a4aa7269-c6e4-4a7b-a7ba-ed28a7bc53b2} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_y9t1nf6z_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_y9t1nf6z.mv_test_03327. (ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41396) (comment: 03327_permissions_on_refresh_mv.sh) (query 3, line 4) (in query: system start view mv_test_03327;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d09340 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d078d1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000016d06c71 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000016cceb63 8. ./src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x0000000018e51949 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55f78 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:09:39.541852 [ 1855 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_y9t1nf6z_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_y9t1nf6z.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d09340 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d078d1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000016d06c71 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000016cceb63 8. ./src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x0000000018e51949 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55f78 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:09:39.822555 [ 1855 ] {d5607aa7-2af6-428d-bfae-b422b11a4075} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_y9t1nf6z_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_y9t1nf6z.mv_test_03327. (ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41396) (comment: 03327_permissions_on_refresh_mv.sh) (query 5, line 6) (in query: system wait view mv_test_03327;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d09340 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d078d1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000016d06c71 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000016cceb63 8. ./src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001819c9bc 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1382: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000018e5c6bf 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:724: DB::InterpreterSystemQuery::execute() @ 0x0000000018e5411b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:09:39.838829 [ 1855 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_y9t1nf6z_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_y9t1nf6z.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d09340 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d078d1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000016d06c71 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000016cceb63 8. ./src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001819c9bc 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1382: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000018e5c6bf 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:724: DB::InterpreterSystemQuery::execute() @ 0x0000000018e5411b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:09:39.950820 [ 1855 ] {bb181d4e-99a9-46d1-8e2b-804f0f7a2fca} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_y9t1nf6z_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_y9t1nf6z.mv_test_03327. (ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41396) (comment: 03327_permissions_on_refresh_mv.sh) (query 6, line 7) (in query: system stop view mv_test_03327;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d09340 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d078d1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000016d06c71 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000016cceb63 8. ./src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x0000000018e51949 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55f78 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:09:39.953693 [ 1855 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_y9t1nf6z_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_y9t1nf6z.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d09340 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d078d1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000016d06c71 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000016cceb63 8. ./src/Access/ContextAccess.h:256: DB::InterpreterSystemQuery::startStopAction(unsigned long, bool) @ 0x0000000018e51949 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55f78 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:09:40.070096 [ 1855 ] {05a136a8-9b95-4ad0-a89b-7b5089292fe6} executeQuery: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_y9t1nf6z_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_y9t1nf6z.mv_test_03327. (ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41396) (comment: 03327_permissions_on_refresh_mv.sh) (query 7, line 8) (in query: system cancel view mv_test_03327;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d09340 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d078d1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000016d06c71 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000016cceb63 8. ./src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001819c9bc 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1382: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000018e5c6bf 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:728: DB::InterpreterSystemQuery::execute() @ 0x0000000018e546c4 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:09:40.087580 [ 1855 ] {} TCPHandler: Code: 497. DB::Exception: user_03327_permissions_on_refresh_mv_test_y9t1nf6z_1: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM VIEWS ON test_y9t1nf6z.mv_test_03327. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d09340 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d078d1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000016d06c71 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000016cceb63 8. ./src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001819c9bc 9. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1382: DB::InterpreterSystemQuery::getRefreshTasks() @ 0x0000000018e5c6bf 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:728: DB::InterpreterSystemQuery::execute() @ 0x0000000018e546c4 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:09:53.601651 [ 2052 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: non_exist_user: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:09:53.601981 [ 2052 ] {} ServerErrorHandler: Code: 516. DB::Exception: non_exist_user: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:09:53.892171 [ 2064 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:09:53.893106 [ 2064 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:09:54.808203 [ 2052 ] {c31001e3-7648-4c9d-a041-4661bd369079} executeQuery: Code: 53. DB::Exception: Trying to compare constants of incompatible types (String and Decimal64), please verify that table constraints are defined using correct types, constraints can be ignored by disabling 'optimize_using_constraints'. Constraints for table can be modified using 'ALTER TABLE ... ADD/DROP CONSTRAINT' query. (TYPE_MISMATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36646) (comment: 03362_optimize_using_constraints_type_mismatch.sql) (query 3, line 3) (in query: SELECT 1 FROM t0 WHERE t0.c0 = t0.c0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x0000000017017ae6 4. ./build_docker/./src/Interpreters/ComparisonGraph.cpp:157: DB::ComparisonGraph>::buildGraphFromNodesGraph(DB::ComparisonGraph>::Graph const&) @ 0x00000000181793b2 5. ./build_docker/./src/Interpreters/ComparisonGraph.cpp:312: DB::ComparisonGraph>::ComparisonGraph(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000181765bc 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::ConstraintsDescription::getQueryTreeData(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001aa0d0cf 7. ./build_docker/./src/Analyzer/Passes/ConvertQueryToCNFPass.cpp:668: DB::(anonymous namespace)::ConvertQueryToCNFVisitor::enterImpl(std::shared_ptr&)::'lambda'(std::shared_ptr&)::operator()(std::shared_ptr&) const @ 0x0000000017b1ed96 8. ./build_docker/./src/Analyzer/Passes/ConvertQueryToCNFPass.cpp:737: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x0000000017b1cce3 9. ./build_docker/./src/Analyzer/Passes/ConvertQueryToCNFPass.cpp:755: DB::ConvertLogicalExpressionToCNFPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017b1c8fd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:09:54.904656 [ 2052 ] {} TCPHandler: Code: 53. DB::Exception: Trying to compare constants of incompatible types (String and Decimal64), please verify that table constraints are defined using correct types, constraints can be ignored by disabling 'optimize_using_constraints'. Constraints for table can be modified using 'ALTER TABLE ... ADD/DROP CONSTRAINT' query. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x0000000017017ae6 4. ./build_docker/./src/Interpreters/ComparisonGraph.cpp:157: DB::ComparisonGraph>::buildGraphFromNodesGraph(DB::ComparisonGraph>::Graph const&) @ 0x00000000181793b2 5. ./build_docker/./src/Interpreters/ComparisonGraph.cpp:312: DB::ComparisonGraph>::ComparisonGraph(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000181765bc 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::ConstraintsDescription::getQueryTreeData(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001aa0d0cf 7. ./build_docker/./src/Analyzer/Passes/ConvertQueryToCNFPass.cpp:668: DB::(anonymous namespace)::ConvertQueryToCNFVisitor::enterImpl(std::shared_ptr&)::'lambda'(std::shared_ptr&)::operator()(std::shared_ptr&) const @ 0x0000000017b1ed96 8. ./build_docker/./src/Analyzer/Passes/ConvertQueryToCNFPass.cpp:737: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x0000000017b1cce3 9. ./build_docker/./src/Analyzer/Passes/ConvertQueryToCNFPass.cpp:755: DB::ConvertLogicalExpressionToCNFPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017b1c8fd 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:09:56.785583 [ 2054 ] {089bb41e-f892-4024-a14f-38dcd2de5c9b} executeQuery: Code: 81. DB::Exception: Database test_if9jcf2k does not exist. (UNKNOWN_DATABASE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48550) (comment: 03326_protobuf_schemas_race.sh) (query 4, line 10) (in query: DROP TABLE table_file;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:427: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cda58 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4304 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000188edc78 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000188ed095 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000188ec24a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000188ebf70 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:09:56.828461 [ 2054 ] {} TCPHandler: Code: 81. DB::Exception: Database test_if9jcf2k does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:427: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cda58 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4304 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000188edc78 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000188ed095 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000188ec24a 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000188ebf70 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:09:57.375713 [ 2052 ] {2f1d2e59-95da-4395-b83b-46c0587984e3} executeQuery: Code: 41. DB::Exception: Value 0 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('00', '%m'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 5, line 9) (in query: select parseDateTime('00', '%m');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:57.381162 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 0 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('00', '%m'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:57.399068 [ 2052 ] {f46f7850-db1d-4704-8a9d-229fb045c4ec} executeQuery: Code: 41. DB::Exception: Value 13 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('13', '%m'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 6, line 10) (in query: select parseDateTime('13', '%m');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:57.420655 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 13 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('13', '%m'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:57.589116 [ 2052 ] {cd5e3d5c-54d8-4386-882f-7a0d220a5f7f} executeQuery: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%m'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 7, line 11) (in query: select parseDateTime('12345', '%m');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:57.593552 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%m'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:57.691897 [ 2052 ] {8b044954-7484-407d-8bec-6e915628b33f} executeQuery: Code: 41. DB::Exception: Value 0 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('00', '%c'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 11, line 15) (in query: select parseDateTime('00', '%c');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:57.697272 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 0 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('00', '%c'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:57.707847 [ 2052 ] {e6d27fdf-92f8-4220-b830-44aab817c78d} executeQuery: Code: 41. DB::Exception: Value 13 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('13', '%c'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 12, line 16) (in query: select parseDateTime('13', '%c');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:57.708657 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 13 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('13', '%c'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:57.715397 [ 2052 ] {eb3d90a5-09a9-407b-9ca6-a3c85982de6c} executeQuery: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%c'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 13, line 17) (in query: select parseDateTime('12345', '%c');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:57.716414 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%c'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:57.861536 [ 2052 ] {8b87eae4-07da-45f1-980e-c9354052cb1e} executeQuery: Code: 41. DB::Exception: Unable to parse fragment %b from abc because of unknown month of year short text abc: In scope SELECT parseDateTime('abc', '%b'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 16, line 20) (in query: select parseDateTime('abc', '%b');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:57.862376 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Unable to parse fragment %b from abc because of unknown month of year short text abc: In scope SELECT parseDateTime('abc', '%b'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.018301 [ 2052 ] {d7fb7d32-9ed4-4a6b-a2eb-6d93090c7f41} executeQuery: Code: 41. DB::Exception: Unable to parse first part of fragment %M from summer because of unknown month of year text: sum: In scope SELECT parseDateTime('summer', '%M'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 21, line 25) (in query: select parseDateTime('summer', '%M');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.021240 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Unable to parse first part of fragment %M from summer because of unknown month of year text: sum: In scope SELECT parseDateTime('summer', '%M'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.179275 [ 2052 ] {a0573ffc-5df6-4a82-a497-c1f42e4f3909} executeQuery: Code: 41. DB::Exception: Value 60 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('60', '%M', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 26, line 30) (in query: select parseDateTime('60', '%M', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.180811 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 60 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('60', '%M', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.208398 [ 2052 ] {72e023c0-6f31-49ad-b8bb-c58833ae74dc} executeQuery: Code: 41. DB::Exception: Value -29 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('-1', '%M', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 27, line 31) (in query: select parseDateTime('-1', '%M', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.215202 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value -29 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('-1', '%M', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.223214 [ 2052 ] {1f39ae25-d5bf-4855-ab3c-637ec31eb701} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%M', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 28, line 32) (in query: select parseDateTime('123456789', '%M', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.223882 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%M', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.372020 [ 2052 ] {94432551-ec27-447e-b431-e75db66d6ffa} executeQuery: Code: 41. DB::Exception: Value 0 for day of month must be in the range [1, 31]: In scope SELECT parseDateTime('00', '%d'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 33, line 39) (in query: select parseDateTime('00', '%d');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.374787 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 0 for day of month must be in the range [1, 31]: In scope SELECT parseDateTime('00', '%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.423284 [ 2052 ] {d0b4fd5c-c56c-4aa4-bf9c-ea0d4798e86d} executeQuery: Code: 41. DB::Exception: Value 32 for day of month must be in the range [1, 31]: In scope SELECT parseDateTime('32', '%d'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 34, line 40) (in query: select parseDateTime('32', '%d');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.424079 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 32 for day of month must be in the range [1, 31]: In scope SELECT parseDateTime('32', '%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.448760 [ 2052 ] {631f2237-dceb-490d-97a3-5afcc412bbfd} executeQuery: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%d'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 35, line 41) (in query: select parseDateTime('12345', '%d');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.450465 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.457259 [ 2052 ] {f1eb2006-9123-4e0b-ab84-2082a5a0e313} executeQuery: Code: 41. DB::Exception: Invalid date, out of range (year: 2000 month: 2 day_of_month: 31): In scope SELECT parseDateTime('02-31', '%m-%d'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 36, line 42) (in query: select parseDateTime('02-31', '%m-%d');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.457967 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid date, out of range (year: 2000 month: 2 day_of_month: 31): In scope SELECT parseDateTime('02-31', '%m-%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.479480 [ 2052 ] {f7570b48-5ae1-4935-8c28-db11b839efea} executeQuery: Code: 41. DB::Exception: Invalid date, out of range (year: 2000 month: 4 day_of_month: 31): In scope SELECT parseDateTime('04-31', '%m-%d'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 37, line 43) (in query: select parseDateTime('04-31', '%m-%d');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.518493 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid date, out of range (year: 2000 month: 4 day_of_month: 31): In scope SELECT parseDateTime('04-31', '%m-%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.794001 [ 2052 ] {4748756b-8b4e-4b52-affd-1413f2b4febf} executeQuery: Code: 41. DB::Exception: Invalid date, out of range (year: 2001 month: 2 day_of_month: 29): In scope SELECT parseDateTime('2001-02-29', '%Y-%m-%d'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 42, line 49) (in query: select parseDateTime('2001-02-29', '%Y-%m-%d');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:58.800525 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid date, out of range (year: 2001 month: 2 day_of_month: 29): In scope SELECT parseDateTime('2001-02-29', '%Y-%m-%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:59.402861 [ 2052 ] {8997b9ad-181f-4dbf-a1dd-34721f6ea9bf} executeQuery: Code: 41. DB::Exception: Invalid day of year, out of range (year: 1981 day of year: 366): In scope SELECT parseDateTime('1981 366', '%Y %j'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 57, line 66) (in query: select parseDateTime('1981 366', '%Y %j');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:59.403598 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid day of year, out of range (year: 1981 day of year: 366): In scope SELECT parseDateTime('1981 366', '%Y %j'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:59.436987 [ 2052 ] {fd34de54-9618-467f-9827-aff906ffa433} executeQuery: Code: 41. DB::Exception: Value 367 for day of year must be in the range [1, 366]: In scope SELECT parseDateTime('367', '%j'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 58, line 67) (in query: select parseDateTime('367', '%j');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:59.444277 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 367 for day of year must be in the range [1, 366]: In scope SELECT parseDateTime('367', '%j'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:59.462156 [ 2052 ] {b40b6bd7-95aa-4e91-ac08-d442da48ac21} executeQuery: Code: 41. DB::Exception: Value 0 for day of year must be in the range [1, 366]: In scope SELECT parseDateTime('000', '%j'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 59, line 68) (in query: select parseDateTime('000', '%j');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:59.467189 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 0 for day of year must be in the range [1, 366]: In scope SELECT parseDateTime('000', '%j'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:59.537443 [ 2052 ] {e668aa48-0196-4c26-b72b-f3a8d30fca78} executeQuery: Code: 41. DB::Exception: Invalid day of year, out of range (year: 2001 day of year: 366): In scope SELECT parseDateTime('2000 366 2001', '%Y %j %Y'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 60, line 69) (in query: -- The last one is chosen if multiple day of years are supplied. select parseDateTime('2000 366 2001', '%Y %j %Y');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:59.548084 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid day of year, out of range (year: 2001 day of year: 366): In scope SELECT parseDateTime('2000 366 2001', '%Y %j %Y'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:59.817333 [ 2052 ] {327ca012-b7bb-43e6-85d8-dc1578d17faf} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('24', '%H', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 66, line 78) (in query: select parseDateTime('24', '%H', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:59.832438 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('24', '%H', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:59.846834 [ 2052 ] {9d1b8f92-a0f1-4aa5-ab98-947f71355e50} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('-1', '%H', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 67, line 79) (in query: select parseDateTime('-1', '%H', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:59.849038 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('-1', '%H', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:59.866233 [ 2052 ] {651140e3-f481-4a4f-807f-7bcad2b3a4e9} executeQuery: Code: 41. DB::Exception: Invalid format input 1234567 is malformed at 34567: In scope SELECT parseDateTime('1234567', '%H', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 68, line 80) (in query: select parseDateTime('1234567', '%H', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:09:59.867383 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid format input 1234567 is malformed at 34567: In scope SELECT parseDateTime('1234567', '%H', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.002952 [ 2052 ] {5b3cddc6-40f9-41e2-b01d-121804298f1f} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('24', '%k', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 73, line 85) (in query: select parseDateTime('24', '%k', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.003724 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('24', '%k', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.033598 [ 2052 ] {4e848bdd-5726-4aa8-b94b-45443bec58d2} executeQuery: Code: 41. DB::Exception: Unable to parse fragment %k from -1 because read number failed: In scope SELECT parseDateTime('-1', '%k', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 74, line 86) (in query: select parseDateTime('-1', '%k', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.036821 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Unable to parse fragment %k from -1 because read number failed: In scope SELECT parseDateTime('-1', '%k', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.043729 [ 2052 ] {1afc3169-ebee-4984-8030-03dc5aab04fc} executeQuery: Code: 41. DB::Exception: Invalid format input 1234567 is malformed at 34567: In scope SELECT parseDateTime('1234567', '%k', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 75, line 87) (in query: select parseDateTime('1234567', '%k', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.047266 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid format input 1234567 is malformed at 34567: In scope SELECT parseDateTime('1234567', '%k', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.241561 [ 2052 ] {5773921c-18a1-4123-9d3a-3d959e05de33} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%h', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 80, line 94) (in query: select parseDateTime('00', '%h', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.242298 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%h', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.265024 [ 2052 ] {d2df86fd-27ef-44be-bea6-848f772848a6} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%h', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 81, line 95) (in query: select parseDateTime('13', '%h', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.280758 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%h', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.291269 [ 2052 ] {a6d7bdc0-bdd1-4772-98f9-ed5deb1cf3b7} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%h', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 82, line 96) (in query: select parseDateTime('123456789', '%h', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.291967 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%h', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.541820 [ 2052 ] {82577e4c-6da2-4175-ba2c-64a5afe5b2e8} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%I', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 87, line 101) (in query: select parseDateTime('00', '%I', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.543089 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%I', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.593221 [ 2052 ] {f3147165-01a3-482a-9f56-d3a456713694} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%I', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 88, line 102) (in query: select parseDateTime('13', '%I', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.597999 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%I', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.605727 [ 2052 ] {36d114d9-48ba-4a8d-978a-31300133f45d} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%I', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 89, line 103) (in query: select parseDateTime('123456789', '%I', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.606971 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%I', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.767382 [ 2052 ] {25c6d6f8-989d-44c5-89be-6cc6038e08e6} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%l', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 94, line 108) (in query: select parseDateTime('00', '%l', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.768485 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%l', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.778167 [ 2052 ] {492cd7b1-f260-4f0d-a82c-09d38001dc72} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%l', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 95, line 109) (in query: select parseDateTime('13', '%l', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.779674 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%l', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.793020 [ 2052 ] {f425ebc5-b7f9-412b-9eab-f42a2b5264a4} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%l', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 96, line 110) (in query: select parseDateTime('123456789', '%l', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:00.793824 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%l', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:01.505210 [ 2052 ] {1c4af195-e54b-4bd6-b910-a13816bd5041} executeQuery: Code: 41. DB::Exception: Value 60 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('60', '%i', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 114, line 132) (in query: select parseDateTime('60', '%i', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:01.507310 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 60 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('60', '%i', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:01.578813 [ 1851 ] {a5f9e33c-cde0-4b65-a869-607591a7bc72} executeQuery: Code: 252. DB::Exception: Too many parts (3 with average size of 121.00 B) in table 'test_gddapazg.test (98e27172-c90d-4930-90d8-01eab4721861)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60008) (comment: 02458_relax_too_many_parts.sql) (query 8, line 10) (in query: INSERT INTO test VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x000000001b3ae3ac 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4937: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001b3480f5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000001b7ffc7b 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0471 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afad9 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x000000001bd2b0a2 13. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbea796 14. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:10:01.581791 [ 2052 ] {fcbf96cf-3fbe-48d3-840b-bb9562602545} executeQuery: Code: 41. DB::Exception: Value -29 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('-1', '%i', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 115, line 133) (in query: select parseDateTime('-1', '%i', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:01.595441 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value -29 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('-1', '%i', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:01.601831 [ 1851 ] {} TCPHandler: Code: 252. DB::Exception: Too many parts (3 with average size of 121.00 B) in table 'test_gddapazg.test (98e27172-c90d-4930-90d8-01eab4721861)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x000000001b3ae3ac 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4937: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001b3480f5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000001b7ffc7b 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0471 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afad9 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x000000001bd2b0a2 13. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbea796 14. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:10:01.651680 [ 2052 ] {353e98be-6c3b-46a4-9fb5-a1815712a9e8} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%i', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 116, line 134) (in query: select parseDateTime('123456789', '%i', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:01.661972 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%i', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:01.796103 [ 2052 ] {14158b5b-f5ed-4fed-bffd-0d8d86ce28e3} executeQuery: Code: 41. DB::Exception: Value 60 for second must be in the range [0, 59]: In scope SELECT parseDateTime('60', '%s', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 120, line 140) (in query: select parseDateTime('60', '%s', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:01.799093 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 60 for second must be in the range [0, 59]: In scope SELECT parseDateTime('60', '%s', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:01.823180 [ 2052 ] {3376e004-0f93-43f7-ba07-180f37c67bcf} executeQuery: Code: 41. DB::Exception: Value -29 for second must be in the range [0, 59]: In scope SELECT parseDateTime('-1', '%s', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 121, line 141) (in query: select parseDateTime('-1', '%s', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:01.824132 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value -29 for second must be in the range [0, 59]: In scope SELECT parseDateTime('-1', '%s', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:01.859917 [ 2052 ] {e76eca20-2c26-4404-8d59-3d9d44038de2} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%s', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 122, line 142) (in query: select parseDateTime('123456789', '%s', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:01.881061 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%s', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df58c6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:01.936225 [ 1851 ] {69f0259e-e7f1-41aa-b232-f6b342e5388d} executeQuery: Code: 252. DB::Exception: Too many parts (3 with average size of 146.00 B) in table 'test_gddapazg.test (98e27172-c90d-4930-90d8-01eab4721861)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60008) (comment: 02458_relax_too_many_parts.sql) (query 15, line 22) (in query: INSERT INTO test VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x000000001b3ae3ac 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4937: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001b3480f5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000001b7ffc7b 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0471 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afad9 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x000000001bd2b0a2 13. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbea796 14. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:10:01.947020 [ 1851 ] {} TCPHandler: Code: 252. DB::Exception: Too many parts (3 with average size of 146.00 B) in table 'test_gddapazg.test (98e27172-c90d-4930-90d8-01eab4721861)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x000000001b3ae3ac 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4937: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001b3480f5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000001b7ffc7b 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0471 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afad9 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x000000001bd2b0a2 13. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbea796 14. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:10:02.106742 [ 2052 ] {83ef1f3d-4565-4f5a-ad84-5fdfac254faf} executeQuery: Code: 243. DB::Exception: Unable to parse fragment %f from 42 because mysqlMicrosecond requires size >= 6: In scope SELECT parseDateTime('42', '%f', 'UTC') = toDateTime('1970-01-01 00:00:00', 'UTC'). (NOT_ENOUGH_SPACE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 125, line 147) (in query: select parseDateTime('42', '%f', 'UTC') = toDateTime('1970-01-01 00:00:00', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:10:02.115152 [ 2052 ] {} TCPHandler: Code: 243. DB::Exception: Unable to parse fragment %f from 42 because mysqlMicrosecond requires size >= 6: In scope SELECT parseDateTime('42', '%f', 'UTC') = toDateTime('1970-01-01 00:00:00', 'UTC'). (NOT_ENOUGH_SPACE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:10:02.145467 [ 2052 ] {dc7466c3-b41d-4eb8-b546-ad70389d28f8} executeQuery: Code: 41. DB::Exception: Unable to parse fragment %f from ABCD because  is not a number: In scope SELECT parseDateTime('12ABCD', '%f', 'UTC') = toDateTime('1970-01-01 00:00:00', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 126, line 148) (in query: select parseDateTime('12ABCD', '%f', 'UTC') = toDateTime('1970-01-01 00:00:00', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:10:02.146885 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Unable to parse fragment %f from ABCD because  is not a number: In scope SELECT parseDateTime('12ABCD', '%f', 'UTC') = toDateTime('1970-01-01 00:00:00', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:10:02.766908 [ 2052 ] {f43022ee-d6fd-44cb-b91c-96e113978954} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 137, line 164) (in query: -- Error handling select parseDateTime();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df597ef 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:02.768016 [ 2052 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df597ef 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:02.781661 [ 2052 ] {b81231e9-7265-4499-af39-e99efe83a972} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT parseDateTime('12 AM', '%h %p', 'UTC', 'a fourth argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 138, line 166) (in query: select parseDateTime('12 AM', '%h %p', 'UTC', 'a fourth argument');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df597ef 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:02.795150 [ 2052 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT parseDateTime('12 AM', '%h %p', 'UTC', 'a fourth argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::(anonymous namespace)::FunctionParseDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df597ef 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:02.966537 [ 2052 ] {7845643d-9ba3-4cc0-8291-b7b9754c5532} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 3rd argument 'timezone' to function 'parseDateTime'. Expected: const String, got: String: In scope SELECT parseDateTime('', '', toString(number)) FROM numbers(13). (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 139, line 168) (in query: -- Fuzzer crash bug #53715 select parseDateTime('', '', toString(number)) from numbers(13);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f35a 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df597ef 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:10:02.976118 [ 2052 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 3rd argument 'timezone' to function 'parseDateTime'. Expected: const String, got: String: In scope SELECT parseDateTime('', '', toString(number)) FROM numbers(13). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f35a 6. DB::(anonymous namespace)::FunctionParseDateTimeImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df597ef 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:10:03.022675 [ 2052 ] {9302e8bf-708c-4b98-ba8b-8ac4e79544b2} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('Aug 13, 2022, 7:58:32 PM', '%b %e, %G, %h:%i:%s %p', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 140, line 171) (in query: -- %h select parseDateTime('Aug 13, 2022, 7:58:32 PM', '%b %e, %G, %h:%i:%s %p', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.050762 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('Aug 13, 2022, 7:58:32 PM', '%b %e, %G, %h:%i:%s %p', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.210191 [ 2052 ] {abc4ed79-0c24-41b6-a58c-971e4b108d35} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('Aug 13, 2022, 7:58:32', '%b %e, %G, %H:%i:%s', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 144, line 177) (in query: -- %H select parseDateTime('Aug 13, 2022, 7:58:32', '%b %e, %G, %H:%i:%s', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.213343 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('Aug 13, 2022, 7:58:32', '%b %e, %G, %H:%i:%s', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.336313 [ 2052 ] {fce35c9b-c7c3-4157-a3a9-71835a086ef4} executeQuery: Code: 41. DB::Exception: Value 64 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('8 13, 2022, 7:58:32', '%m %e, %G, %k:%i:%s', 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 148, line 183) (in query: -- %m select parseDateTime('8 13, 2022, 7:58:32', '%m %e, %G, %k:%i:%s', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.337396 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 64 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('8 13, 2022, 7:58:32', '%m %e, %G, %k:%i:%s', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.462370 [ 2052 ] {c81835b3-d4a9-424e-b961-a027ba4b0d76} executeQuery: Code: 243. DB::Exception: Unable to parse fragment %Y from because readNumber4 requires size >= 4: In scope SELECT parseDateTime(''). (NOT_ENOUGH_SPACE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 154, line 193) (in query: select parseDateTime('');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.463540 [ 2052 ] {} TCPHandler: Code: 243. DB::Exception: Unable to parse fragment %Y from because readNumber4 requires size >= 4: In scope SELECT parseDateTime(''). (NOT_ENOUGH_SPACE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df589ec 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.605041 [ 2052 ] {a274f7c8-2b28-4338-919f-0cf405085057} executeQuery: Code: 243. DB::Exception: Unable to parse fragment %Y from because readNumber4 requires size >= 4: In scope SELECT parseDateTime64(''). (NOT_ENOUGH_SPACE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 155, line 195) (in query: -- ------------------------------------------------------------------------------------------------------------------------- -- Tests for parseDateTime64, these are not systematic select parseDateTime64('');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbaa72 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.608244 [ 2052 ] {} TCPHandler: Code: 243. DB::Exception: Unable to parse fragment %Y from because readNumber4 requires size >= 4: In scope SELECT parseDateTime64(''). (NOT_ENOUGH_SPACE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbaa72 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.622772 [ 2052 ] {d311559a-0cc7-4243-95fe-98ac741abe58} executeQuery: Code: 243. DB::Exception: Unable to parse fragment %f from 118 because readNumber6 requires size >= 6: In scope SELECT parseDateTime64('2021-01-04 23:12:34.118'). (NOT_ENOUGH_SPACE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 156, line 199) (in query: select parseDateTime64('2021-01-04 23:12:34.118');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbaa72 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.623737 [ 2052 ] {} TCPHandler: Code: 243. DB::Exception: Unable to parse fragment %f from 118 because readNumber6 requires size >= 6: In scope SELECT parseDateTime64('2021-01-04 23:12:34.118'). (NOT_ENOUGH_SPACE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbaa72 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.659646 [ 2052 ] {6c8b53ab-e18b-4445-b05d-a3912cdd9d81} executeQuery: Code: 243. DB::Exception: Unable to parse fragment %f from 123 because readNumber6 requires size >= 6: In scope SELECT parseDateTime64('2177-10-09 10:30:10.123'). (NOT_ENOUGH_SPACE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 157, line 200) (in query: select parseDateTime64('2177-10-09 10:30:10.123');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbaa72 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.662136 [ 2052 ] {} TCPHandler: Code: 243. DB::Exception: Unable to parse fragment %f from 123 because readNumber6 requires size >= 6: In scope SELECT parseDateTime64('2177-10-09 10:30:10.123'). (NOT_ENOUGH_SPACE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbaa72 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.728366 [ 2052 ] {715d2eac-238a-4921-8d21-9a6cd9589a4c} executeQuery: Code: 243. DB::Exception: Unable to parse fragment %f from 118 because readNumber6 requires size >= 6: In scope SELECT parseDateTime64('2021-01-04 23:12:34.118', '%Y-%m-%d %H:%i:%s.%f'). (NOT_ENOUGH_SPACE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 160, line 203) (in query: select parseDateTime64('2021-01-04 23:12:34.118', '%Y-%m-%d %H:%i:%s.%f');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbaa72 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.735562 [ 2052 ] {} TCPHandler: Code: 243. DB::Exception: Unable to parse fragment %f from 118 because readNumber6 requires size >= 6: In scope SELECT parseDateTime64('2021-01-04 23:12:34.118', '%Y-%m-%d %H:%i:%s.%f'). (NOT_ENOUGH_SPACE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbaa72 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.893317 [ 2052 ] {d2db7f52-75f4-4542-af88-c9bf807e3d05} executeQuery: Code: 41. DB::Exception: Invalid format input 2021-01-04 23:12:34.11811235 is malformed at 35: In scope SELECT parseDateTime64('2021-01-04 23:12:34.11811235', '%Y-%m-%d %H:%i:%s.%f'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 161, line 204) (in query: select parseDateTime64('2021-01-04 23:12:34.11811235', '%Y-%m-%d %H:%i:%s.%f');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbacfe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.895151 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid format input 2021-01-04 23:12:34.11811235 is malformed at 35: In scope SELECT parseDateTime64('2021-01-04 23:12:34.11811235', '%Y-%m-%d %H:%i:%s.%f'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbacfe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.908468 [ 2052 ] {217b9088-ff9c-47bf-b5b5-6239c0b2fd39} executeQuery: Code: 41. DB::Exception: Invalid format input 2021-01-04 23:12:34.118112 is malformed at .118112: In scope SELECT parseDateTime64('2021-01-04 23:12:34.118112', '%Y-%m-%d %H:%i:%s'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 162, line 205) (in query: select parseDateTime64('2021-01-04 23:12:34.118112', '%Y-%m-%d %H:%i:%s');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbacfe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.923329 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid format input 2021-01-04 23:12:34.118112 is malformed at .118112: In scope SELECT parseDateTime64('2021-01-04 23:12:34.118112', '%Y-%m-%d %H:%i:%s'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbacfe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:03.980662 [ 419 ] {bab9ade3-ef7f-4a00-8ef0-691d58ce7c89} executeQuery: Code: 44. DB::Exception: Data type JSON is not allowed in ORDER BY keys, because its values are not comparable. Set setting allow_not_comparable_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60098) (comment: 03287_not_comparable_types_in_order_by_and_comparison_functions.sql) (query 5, line 6) (in query: select * from test order by json1 settings allow_not_comparable_types_in_order_by=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4168: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000017ab8030 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab5afa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7f747 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:10:03.990595 [ 419 ] {} TCPHandler: Code: 44. DB::Exception: Data type JSON is not allowed in ORDER BY keys, because its values are not comparable. Set setting allow_not_comparable_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4168: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000017ab8030 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab5afa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7f747 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:10:04.005059 [ 2052 ] {4ba04632-6bc2-466b-89a7-3649af77a084} executeQuery: Code: 41. DB::Exception: Invalid date, out of range (year: 2023 month: 2 day_of_month: 29): In scope SELECT parseDateTime64('2023-02-29 11:22:33.123433', '%Y-%m-%d %H:%i:%s.%f'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 164, line 208) (in query: select parseDateTime64('2023-02-29 11:22:33.123433', '%Y-%m-%d %H:%i:%s.%f');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbacfe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:04.014319 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Invalid date, out of range (year: 2023 month: 2 day_of_month: 29): In scope SELECT parseDateTime64('2023-02-29 11:22:33.123433', '%Y-%m-%d %H:%i:%s.%f'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbacfe 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:04.499606 [ 419 ] {edcf7358-9a7f-4188-93f3-a6d546f2b27c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (JSON, JSON) of function less, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT json1 < json2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60098) (comment: 03287_not_comparable_types_in_order_by_and_comparison_functions.sql) (query 7, line 8) (in query: select json1 < json2 from test settings allow_not_comparable_types_in_comparison_functions=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c3b1e78 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:04.560553 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (JSON, JSON) of function less, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT json1 < json2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c3b1e78 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:04.850084 [ 2052 ] {8089337e-86ab-4b8a-a27d-f69b45f1efb0} executeQuery: Code: 41. DB::Exception: Value 1899 for year must be in the range [1900, 2299]: In scope SELECT parseDateTime64('1899-12-31 23:59:59', '%Y-%m-%d %H:%i:%s'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 175, line 222) (in query: -- Test parseDataTime64 supports range between 1900 - 2299 select parseDateTime64('1899-12-31 23:59:59', '%Y-%m-%d %H:%i:%s');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbaa72 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:04.851207 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 1899 for year must be in the range [1900, 2299]: In scope SELECT parseDateTime64('1899-12-31 23:59:59', '%Y-%m-%d %H:%i:%s'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbaa72 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:05.218953 [ 2052 ] {d9e16250-4285-4921-952c-9811ac2fef89} executeQuery: Code: 41. DB::Exception: Value 2300 for year must be in the range [1900, 2299]: In scope SELECT parseDateTime64('2300-01-01 00:00:00', '%Y-%m-%d %H:%i:%s'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36708) (comment: 02668_parse_datetime.sql) (query 184, line 232) (in query: select parseDateTime64('2300-01-01 00:00:00', '%Y-%m-%d %H:%i:%s');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbaa72 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:05.221227 [ 2052 ] {} TCPHandler: Code: 41. DB::Exception: Value 2300 for year must be in the range [1900, 2299]: In scope SELECT parseDateTime64('2300-01-01 00:00:00', '%Y-%m-%d %H:%i:%s'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000dfbaa72 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:05.543326 [ 419 ] {a03c5723-1b51-42e0-b495-e948c5ab5b34} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (JSON, JSON) of function lessOrEquals, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT json1 <= json2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60098) (comment: 03287_not_comparable_types_in_order_by_and_comparison_functions.sql) (query 9, line 10) (in query: select json1 <= json2 from test settings allow_not_comparable_types_in_comparison_functions=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c733378 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:05.544507 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (JSON, JSON) of function lessOrEquals, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT json1 <= json2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c733378 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:05.720306 [ 419 ] {87d53710-e01f-40c2-a53c-0bc969e49d99} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (JSON, JSON) of function greater, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT json1 > json2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60098) (comment: 03287_not_comparable_types_in_order_by_and_comparison_functions.sql) (query 11, line 12) (in query: select json1 > json2 from test settings allow_not_comparable_types_in_comparison_functions=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000accb578 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:05.722549 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (JSON, JSON) of function greater, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT json1 > json2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000accb578 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:05.972774 [ 419 ] {b7e777e8-6207-4cc3-9544-74e95dbc31f3} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (JSON, JSON) of function greaterOrEquals, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT json1 >= json2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60098) (comment: 03287_not_comparable_types_in_order_by_and_comparison_functions.sql) (query 13, line 14) (in query: select json1 >= json2 from test settings allow_not_comparable_types_in_comparison_functions=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b1cd6d8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:05.974299 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (JSON, JSON) of function greaterOrEquals, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT json1 >= json2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b1cd6d8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:06.360228 [ 419 ] {36993091-f765-40b5-b7c0-4b6dc2e45383} executeQuery: Code: 44. DB::Exception: Data type AggregateFunction(sum, UInt64) is not allowed in ORDER BY keys, because its values are not comparable. Set setting allow_not_comparable_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60098) (comment: 03287_not_comparable_types_in_order_by_and_comparison_functions.sql) (query 18, line 20) (in query: select * from test order by agg1 settings allow_not_comparable_types_in_order_by=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4168: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000017ab8030 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab5afa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7f747 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:10:06.362559 [ 419 ] {} TCPHandler: Code: 44. DB::Exception: Data type AggregateFunction(sum, UInt64) is not allowed in ORDER BY keys, because its values are not comparable. Set setting allow_not_comparable_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4168: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x0000000017ab8030 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4171: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab5afa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7f747 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:10:06.443908 [ 419 ] {3eada476-7d21-4e4f-8e27-255ff4864918} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (AggregateFunction(sum, UInt64), AggregateFunction(sum, UInt64)) of function less, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT agg1 < agg2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60098) (comment: 03287_not_comparable_types_in_order_by_and_comparison_functions.sql) (query 20, line 22) (in query: select agg1 < agg2 from test settings allow_not_comparable_types_in_comparison_functions=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c3b1e78 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:06.448889 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (AggregateFunction(sum, UInt64), AggregateFunction(sum, UInt64)) of function less, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT agg1 < agg2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c3b1e78 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:06.558867 [ 419 ] {8050e462-3dd8-4104-b2bc-f72fe580dd21} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (AggregateFunction(sum, UInt64), AggregateFunction(sum, UInt64)) of function lessOrEquals, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT agg1 <= agg2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60098) (comment: 03287_not_comparable_types_in_order_by_and_comparison_functions.sql) (query 22, line 24) (in query: select agg1 <= agg2 from test settings allow_not_comparable_types_in_comparison_functions=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c733378 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:06.565346 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (AggregateFunction(sum, UInt64), AggregateFunction(sum, UInt64)) of function lessOrEquals, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT agg1 <= agg2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c733378 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:06.633835 [ 419 ] {23154807-11ef-42ba-a62c-65a285f8daa6} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (AggregateFunction(sum, UInt64), AggregateFunction(sum, UInt64)) of function greater, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT agg1 > agg2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60098) (comment: 03287_not_comparable_types_in_order_by_and_comparison_functions.sql) (query 24, line 26) (in query: select agg1 > agg2 from test settings allow_not_comparable_types_in_comparison_functions=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000accb578 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:06.635092 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (AggregateFunction(sum, UInt64), AggregateFunction(sum, UInt64)) of function greater, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT agg1 > agg2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000accb578 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:06.701394 [ 419 ] {c9fe1813-759b-467b-bb53-50480826aa69} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (AggregateFunction(sum, UInt64), AggregateFunction(sum, UInt64)) of function greaterOrEquals, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT agg1 >= agg2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60098) (comment: 03287_not_comparable_types_in_order_by_and_comparison_functions.sql) (query 26, line 28) (in query: select agg1 >= agg2 from test settings allow_not_comparable_types_in_comparison_functions=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b1cd6d8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:06.705231 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (AggregateFunction(sum, UInt64), AggregateFunction(sum, UInt64)) of function greaterOrEquals, because some of them are not comparable.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT agg1 >= agg2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b1cd6d8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:06.946067 [ 419 ] {6875ffb0-cce6-4086-832b-58ed02756d31} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (AggregateFunction(sum, UInt64), AggregateFunction(sum, UInt64)) of function equals, because some of them are not comparable for equality.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT agg1 = agg2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60098) (comment: 03287_not_comparable_types_in_order_by_and_comparison_functions.sql) (query 28, line 30) (in query: select agg1 = agg2 from test settings allow_not_comparable_types_in_comparison_functions=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a67688c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:06.954016 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (AggregateFunction(sum, UInt64), AggregateFunction(sum, UInt64)) of function equals, because some of them are not comparable for equality.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT agg1 = agg2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a67688c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:07.159336 [ 419 ] {915f072e-53e4-4cda-a937-a45ef9e8c5f3} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (AggregateFunction(sum, UInt64), AggregateFunction(sum, UInt64)) of function notEquals, because some of them are not comparable for equality.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT agg1 != agg2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60098) (comment: 03287_not_comparable_types_in_order_by_and_comparison_functions.sql) (query 30, line 32) (in query: select agg1 != agg2 from test settings allow_not_comparable_types_in_comparison_functions=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000dab986c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:07.160329 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (AggregateFunction(sum, UInt64), AggregateFunction(sum, UInt64)) of function notEquals, because some of them are not comparable for equality.Set setting allow_not_comparable_types_in_comparison_functions = 1 in order to allow it: In scope SELECT agg1 != agg2 FROM test SETTINGS allow_not_comparable_types_in_comparison_functions = 0. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000dab986c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:12.149454 [ 2054 ] {} DynamicQueryHandler: Code: 48. DB::Exception: Unsupported compression method. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/IO/CompressionMethod.cpp:197: std::unique_ptr> DB::createWriteCompressedWrapper(DB::WriteBuffer*&, DB::CompressionMethod, int, int, unsigned long, char*, unsigned long, bool) @ 0x0000000010ef9180 5. ./build_docker/./src/IO/CompressionMethod.cpp:231: DB::wrapWriteBufferWithCompressionMethod(DB::WriteBuffer*, DB::CompressionMethod, int, int, unsigned long, char*, unsigned long, bool) @ 0x0000000010ef8b1f 6. ./build_docker/./src/Server/HTTPHandler.cpp:314: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1cf53 7. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:10:14.506747 [ 1865 ] {9e2a9c76-2ce2-4ca5-81bb-2224b0ed0937} executeQuery: Code: 43. DB::Exception: First argument of function randomStringUTF8 must have numeric type: In scope SELECT randomStringUTF8('string'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54932) (comment: 01278_random_string_utf8.sql) (query 1, line 1) (in query: SELECT randomStringUTF8('string');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionRandomStringUTF8::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ea9bd53 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:14.518446 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function randomStringUTF8 must have numeric type: In scope SELECT randomStringUTF8('string'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionRandomStringUTF8::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ea9bd53 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:10:14.766466 [ 1859 ] {37581809-56e7-4d6a-bd93-4270a4fdd562} executeQuery: Code: 422. DB::Exception: Unsupported scheme in URI '/': The data format cannot be detected by the contents of the files. You can specify the format manually. (UNSUPPORTED_URI_SCHEME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54918) (comment: 01030_storage_url_syntax.sql) (query 2, line 6) (in query: create table test_table_url_syntax (id UInt32) ENGINE = URL('') ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Common/HTTPConnectionPool.cpp:900: DB::HTTPConnectionPools::Impl::useSecureConnection(Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000010fa76d6 5. ./build_docker/./src/Common/HTTPConnectionPool.cpp:918: DB::HTTPConnectionPools::Impl::getPoolImpl(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000010fa42df 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:834: DB::HTTPConnectionPools::Impl::getPool(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000010fa331a 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:946: DB::HTTPConnectionPools::getPool(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000010fa31ba 8. ./build_docker/./src/IO/HTTPCommon.cpp:62: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000010fc1b00 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:267: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000013ceef45 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000013cef1f4 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000013cefca0 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000013cf2e57 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cec6b9 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000013cf1361 15. DB::ReadBuffer::next() @ 0x0000000008915c7b 16. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000013cee96e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000013ce2eab 18. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::StorageURLSource::getFirstAvailableURIAndReadBuffer(std::__wrap_iter&, std::__wrap_iter const&, std::shared_ptr, std::vector, std::allocator>> const&, String const&, std::function>&)>, DB::ConnectionTimeouts const&, Poco::Net::HTTPBasicCredentials&, std::vector> const&, bool, bool) @ 0x000000001ae84d00 19. ./build_docker/./src/Storages/StorageURL.cpp:858: DB::(anonymous namespace)::ReadBufferIterator::next() @ 0x000000001ae8f83f 20. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcb8734 21. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:556: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe66e 22. ./build_docker/./src/Storages/StorageURL.cpp:1022: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x000000001ae873a8 23. ./build_docker/./src/Storages/StorageURL.cpp:1043: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae7f9fd 24. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae8b72e 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c5a1 26. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c31b 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001ae952f6 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 29. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 30. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 31. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 2025.07.28 06:10:14.767746 [ 1859 ] {} TCPHandler: Code: 422. DB::Exception: Unsupported scheme in URI '/': The data format cannot be detected by the contents of the files. You can specify the format manually. (UNSUPPORTED_URI_SCHEME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Common/HTTPConnectionPool.cpp:900: DB::HTTPConnectionPools::Impl::useSecureConnection(Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000010fa76d6 5. ./build_docker/./src/Common/HTTPConnectionPool.cpp:918: DB::HTTPConnectionPools::Impl::getPoolImpl(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000010fa42df 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:834: DB::HTTPConnectionPools::Impl::getPool(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000010fa331a 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:946: DB::HTTPConnectionPools::getPool(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000010fa31ba 8. ./build_docker/./src/IO/HTTPCommon.cpp:62: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000010fc1b00 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:267: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000013ceef45 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000013cef1f4 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000013cefca0 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000013cf2e57 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cec6b9 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000013cf1361 15. DB::ReadBuffer::next() @ 0x0000000008915c7b 16. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000013cee96e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000013ce2eab 18. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::StorageURLSource::getFirstAvailableURIAndReadBuffer(std::__wrap_iter&, std::__wrap_iter const&, std::shared_ptr, std::vector, std::allocator>> const&, String const&, std::function>&)>, DB::ConnectionTimeouts const&, Poco::Net::HTTPBasicCredentials&, std::vector> const&, bool, bool) @ 0x000000001ae84d00 19. ./build_docker/./src/Storages/StorageURL.cpp:858: DB::(anonymous namespace)::ReadBufferIterator::next() @ 0x000000001ae8f83f 20. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcb8734 21. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:556: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe66e 22. ./build_docker/./src/Storages/StorageURL.cpp:1022: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x000000001ae873a8 23. ./build_docker/./src/Storages/StorageURL.cpp:1043: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae7f9fd 24. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae8b72e 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c5a1 26. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c31b 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001ae952f6 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 29. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 30. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 31. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 2025.07.28 06:10:14.930186 [ 1859 ] {9d8e8b57-c6a8-4ab1-94a6-70d16d0574ee} executeQuery: Code: 42. DB::Exception: Storage URL requires 1-4 arguments: url, name of used format (taken from file extension by default), optional compression method, optional headers (specified as `headers('name'='value', 'name2'='value2')`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54918) (comment: 01030_storage_url_syntax.sql) (query 3, line 8) (in query: create table test_table_url_syntax (id UInt32) ENGINE = URL('','','','') ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageURL.cpp:1598: DB::StorageURL::getConfiguration(absl::lts_20250127::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000001ae8ef59 5. ./build_docker/./src/Storages/StorageURL.cpp:1627: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001ae9511a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:10:14.948435 [ 1859 ] {} TCPHandler: Code: 42. DB::Exception: Storage URL requires 1-4 arguments: url, name of used format (taken from file extension by default), optional compression method, optional headers (specified as `headers('name'='value', 'name2'='value2')`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageURL.cpp:1598: DB::StorageURL::getConfiguration(absl::lts_20250127::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x000000001ae8ef59 5. ./build_docker/./src/Storages/StorageURL.cpp:1627: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001ae9511a 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:10:19.084017 [ 1867 ] {test_4gj73sgi_30324} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 1 (BAD): BAD SQL. Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35864) (comment: 02564_query_id_header.sh) (in query: BAD SQL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:10:19.111135 [ 1867 ] {test_4gj73sgi_30324} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 1 (BAD): BAD SQL. Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:10:27.631622 [ 6818 ] {f63f2491-9b17-42f6-871d-f2931094327e} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00 million, current rows: 111.22 billion. (TOO_MANY_ROWS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35878) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 111222333444 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001c451086 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001c44fff7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c44ea73 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:27.680764 [ 6818 ] {f63f2491-9b17-42f6-871d-f2931094327e} DynamicQueryHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00 million, current rows: 111.22 billion. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001c451086 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001c44fff7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c44ea73 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:10:27.951947 [ 1865 ] {f2509838-9ee0-4203-9cde-db3027c7f58a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35196) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:27.958951 [ 1865 ] {f2509838-9ee0-4203-9cde-db3027c7f58a} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:10:28.126868 [ 2053 ] {610f6189-fb64-43fe-ae61-ec28b9db86bb} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35208) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:28.129352 [ 2053 ] {610f6189-fb64-43fe-ae61-ec28b9db86bb} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:10:28.453258 [ 1851 ] {637a9b1b-5ce8-4939-9af3-ea32c63f06d2} executeQuery: Code: 36. DB::Exception: Codec Delta is not applicable for String because the data type is not of fixed size. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46438) (comment: 01504_compression_multiple_streams.sql) (query 37, line 87) (in query: -- validation still works, non-sense codecs checked CREATE TABLE columns_with_multiple_streams_bad_case ( field0 Nullable(String) CODEC(Delta, LZ4) ) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Compression/CompressionCodecDelta.cpp:177: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:ne190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001ce2a7f3 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001ce1c57a 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001ce786b2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017510d50 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:57: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000017590915 9. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x00000000175110ab 10. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001ce76e9b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b5c42 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:10:28.454497 [ 1851 ] {} TCPHandler: Code: 36. DB::Exception: Codec Delta is not applicable for String because the data type is not of fixed size. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Compression/CompressionCodecDelta.cpp:177: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:ne190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001ce2a7f3 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001ce1c57a 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001ce786b2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017510d50 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:57: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000017590915 9. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x00000000175110ab 10. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001ce76e9b 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b5c42 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:10:28.628698 [ 1851 ] {c6e7b4b8-f336-4993-b61a-7072113732f1} executeQuery: Code: 431. DB::Exception: T64 codec is not supported for specified type String. (ILLEGAL_SYNTAX_FOR_CODEC_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46438) (comment: 01504_compression_multiple_streams.sql) (query 38, line 94) (in query: CREATE TABLE columns_with_multiple_streams_bad_case ( field0 Tuple(Array(UInt64), String) CODEC(T64, LZ4) ) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Compression/CompressionCodecT64.cpp:775: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:ne190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001ce5d8f7 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001ce1c57a 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001ce786b2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017510d50 8. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000001758ddbb 9. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000001761180b 10. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x00000000175110ab 11. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001ce76e9b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b5c42 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:10:28.629950 [ 1851 ] {} TCPHandler: Code: 431. DB::Exception: T64 codec is not supported for specified type String. (ILLEGAL_SYNTAX_FOR_CODEC_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Compression/CompressionCodecT64.cpp:775: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:ne190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001ce5d8f7 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001ce1c57a 6. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000001ce786b2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017510d50 8. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000001758ddbb 9. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000001761180b 10. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x00000000175110ab 11. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001ce76e9b 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b5c42 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:10:28.782560 [ 1865 ] {a5c8f1f2-c189-4f01-949c-dd544523621e} executeQuery: Code: 36. DB::Exception: Cannot specify codec for column type ALIAS. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48746) (comment: 01462_test_codec_on_alias.sql) (query 3, line 5) (in query: CREATE TABLE compression_codec_on_alias (`c0` ALIAS c1 CODEC(ZSTD), `c1` UInt64) ENGINE = MergeTree PARTITION BY c0 ORDER BY c1 SETTINGS index_granularity = 8595, min_bytes_for_wide_part = 321756184, ratio_of_defaults_for_sparse_serialization = 0.6485769152641296, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 119921207, compact_parts_max_granules_to_buffer = 218, compact_parts_merge_max_bytes_to_prefetch_part = 4382126, merge_max_block_size = 20123, old_parts_lifetime = 468., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 95, min_merge_bytes_to_use_direct_io = 8825914786, index_granularity_bytes = 599803, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 43, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 63311, primary_key_compress_block_size = 63387, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:705: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b647e 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:10:28.783653 [ 1865 ] {} TCPHandler: Code: 36. DB::Exception: Cannot specify codec for column type ALIAS. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:705: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b647e 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:10:28.814740 [ 1861 ] {adf5203c-1299-4210-a947-dd5592c78315} StorageBuffer (test_y1oo42aa.buffer_): Destination table test_y1oo42aa.null_ doesn't exist. Block of data is discarded. 2025.07.28 06:10:29.035045 [ 1865 ] {73914e9e-3e75-4d33-aaea-54674feec00a} executeQuery: Code: 36. DB::Exception: Cannot specify codec for column type ALIAS. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48746) (comment: 01462_test_codec_on_alias.sql) (query 7, line 19) (in query: ALTER TABLE compression_codec_on_alias ADD COLUMN `c3` ALIAS c2 CODEC(ZSTD) AFTER c2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/AlterCommands.cpp:134: DB::AlterCommand::parse(DB::ASTAlterCommand const*) @ 0x000000001a9d061a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:158: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889ec2a 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:10:29.039988 [ 1865 ] {} TCPHandler: Code: 36. DB::Exception: Cannot specify codec for column type ALIAS. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/AlterCommands.cpp:134: DB::AlterCommand::parse(DB::ASTAlterCommand const*) @ 0x000000001a9d061a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:158: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889ec2a 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:10:30.333761 [ 2064 ] {7d96c7d9-b28f-4782-bd27-4e30866379ac} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35214) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1048577 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:30.335386 [ 2064 ] {7d96c7d9-b28f-4782-bd27-4e30866379ac} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:10:31.615798 [ 1865 ] {0bffb4d8-c3f0-4378-923f-6fa60aa0e18f} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (24) of function geoToH3 is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT geoToH3(37.63098076, 55.77922738, 24). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48780) (comment: 00926_geo_to_h3.sql) (query 9, line 14) (in query: select geoToH3(37.63098076, 55.77922738, 24);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000ac8294c 4. DB::(anonymous namespace)::FunctionGeoToH3::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ac81faa 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:31.622985 [ 1865 ] {} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (24) of function geoToH3 is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT geoToH3(37.63098076, 55.77922738, 24). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000ac8294c 4. DB::(anonymous namespace)::FunctionGeoToH3::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ac81faa 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:10:32.418618 [ 1808 ] {88b40770-2ed2-40b7-9ea5-e690aa73734e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35230) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1048577 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:32.459347 [ 1808 ] {88b40770-2ed2-40b7-9ea5-e690aa73734e} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:10:33.497387 [ 1860 ] {43928c9c-1974-458c-a0d1-2abb2f305bab} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a ORC format file. Error: std::exception. Code: 1001, type: orc::ParseError, e.what() = Footer is corrupt: STRUCT type 0 has 3 subTypes, but has 2 fieldNames (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/corrupted.orc). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48806) (comment: 02185_orc_corrupted_file.sh) (query 1, line 1) (in query: select * from file('corrupted.orc')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbd0d6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabc85b 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001aabcf8f 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000013cbd11d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000013cba627 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cbeb14 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:10:33.518154 [ 1860 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a ORC format file. Error: std::exception. Code: 1001, type: orc::ParseError, e.what() = Footer is corrupt: STRUCT type 0 has 3 subTypes, but has 2 fieldNames (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/corrupted.orc). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbd0d6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabc85b 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001aabcf8f 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000013cbd11d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000013cba627 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cbeb14 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:10:36.313443 [ 1808 ] {3f6315a9-baaf-4cb9-9ea1-16a502c06580} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35246) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1500001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:36.315265 [ 1808 ] {3f6315a9-baaf-4cb9-9ea1-16a502c06580} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:10:40.529993 [ 2070 ] {1575d060-ba97-41c8-8984-ae8cb9c2683f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35248) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1500001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:40.531435 [ 2070 ] {1575d060-ba97-41c8-8984-ae8cb9c2683f} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:10:46.241918 [ 419 ] {9fc2374c-66ab-4d3a-a4b0-aad98485e23a} executeQuery: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46496) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (query 37, line 113) (in query: -- optimize_skip_unused_shards does not support non-constants select * from dist_01756 where dummy in (select * from system.one);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001aa80a89 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001aa7f201 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa413 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:10:46.246381 [ 419 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001aa80a89 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001aa7f201 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa413 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:10:46.574959 [ 419 ] {e365c4b8-83d2-4aec-bbcf-848706e30d3a} executeQuery: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46496) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (query 38, line 115) (in query: -- this is a constant for analyzer select * from dist_01756 where dummy in (toUInt8(0)) settings enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001aa80a89 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001aa7f201 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1160: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000018947ab6 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:920: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x000000001893be6c 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:930: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000189350eb 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001892fec6 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000018a165ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018a14a56 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000018a1a06d 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:46.576849 [ 419 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001aa80a89 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001aa7f201 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1160: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000018947ab6 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:920: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x000000001893be6c 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:930: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000189350eb 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001892fec6 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000018a165ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018a14a56 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000018a1a06d 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:46.602044 [ 419 ] {70514085-89a5-4a59-8055-c133f869662f} executeQuery: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46496) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (query 39, line 117) (in query: -- NOT IN does not supported select * from dist_01756 where dummy not in (0, 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001aa80a89 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001aa7f201 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa413 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:10:46.609654 [ 419 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001aa80a89 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001aa7f201 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa413 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:10:47.133609 [ 1861 ] {4ff7bbb0-709e-444e-a7fe-c9244c71ed70} executeQuery: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; S. . (SYNTAX_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48284) (comment: 00366_multi_statements.sh) (in query: SELECT 1; S), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:10:47.165431 [ 1861 ] {4ff7bbb0-709e-444e-a7fe-c9244c71ed70} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; S. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:10:47.238520 [ 1851 ] {08c3ae87-5ffb-484d-a381-64a2ca2c44cb} executeQuery: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2. . (SYNTAX_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48300) (comment: 00366_multi_statements.sh) (in query: SELECT 1; SELECT 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:10:47.251730 [ 1851 ] {08c3ae87-5ffb-484d-a381-64a2ca2c44cb} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:10:47.441904 [ 2064 ] {8e850d60-d19e-4383-91ce-36a0f572c87b} executeQuery: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2;. . (SYNTAX_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48304) (comment: 00366_multi_statements.sh) (in query: SELECT 1; SELECT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:10:47.442693 [ 2064 ] {8e850d60-d19e-4383-91ce-36a0f572c87b} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2;. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:10:47.523756 [ 2095 ] {f7f4cafc-8b66-46a1-92b8-2e846d4c4210} executeQuery: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2; SELECT. . (SYNTAX_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48308) (comment: 00366_multi_statements.sh) (in query: SELECT 1; SELECT 2; SELECT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:10:47.529201 [ 2095 ] {f7f4cafc-8b66-46a1-92b8-2e846d4c4210} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error (Multi-statements are not allowed): failed at position 9 (end of query): ; SELECT 2; SELECT. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:10:49.819320 [ 1859 ] {c57fd2ea-d2c3-4dee-9885-2f4d8aabeb42} executeQuery: Code: 715. DB::Exception: The data format cannot be detected by the contents of the files: Poco::Exception. Code: 1000, e.code() = 111, Connection refused (version 25.3.6.10634.altinitytest (altinity build)). You can specify the format manually. (CANNOT_DETECT_FORMAT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54918) (comment: 01030_storage_url_syntax.sql) (query 6, line 16) (in query: create table test_table_url(id UInt32) ENGINE = URL('http://localhost/endpoint') ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:209: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe008 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:556: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe66e 6. ./build_docker/./src/Storages/StorageURL.cpp:1022: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x000000001ae873a8 7. ./build_docker/./src/Storages/StorageURL.cpp:1043: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae7f9fd 8. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae8b72e 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c5a1 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c31b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001ae952f6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:10:49.837386 [ 1859 ] {} TCPHandler: Code: 715. DB::Exception: The data format cannot be detected by the contents of the files: Poco::Exception. Code: 1000, e.code() = 111, Connection refused (version 25.3.6.10634.altinitytest (altinity build)). You can specify the format manually. (CANNOT_DETECT_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:209: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe008 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:556: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe66e 6. ./build_docker/./src/Storages/StorageURL.cpp:1022: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x000000001ae873a8 7. ./build_docker/./src/Storages/StorageURL.cpp:1043: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae7f9fd 8. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae8b72e 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c5a1 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c31b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001ae952f6 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:10:50.441095 [ 1859 ] {d58ea24c-7818-44a4-a3d4-fe35bb18f7b4} executeQuery: Code: 73. DB::Exception: Unknown format ErrorFormat. (UNKNOWN_FORMAT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54918) (comment: 01030_storage_url_syntax.sql) (query 9, line 22) (in query: create table test_table_url(id UInt32) ENGINE = URL('http://localhost/endpoint', 'ErrorFormat') ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Formats/FormatFactory.cpp:937: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000001bc4ac7e 5. ./build_docker/./src/Storages/StorageURL.cpp:168: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae7f7ce 6. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae8b72e 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c5a1 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c31b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001ae952f6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:50.445223 [ 1859 ] {} TCPHandler: Code: 73. DB::Exception: Unknown format ErrorFormat. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Formats/FormatFactory.cpp:937: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000001bc4ac7e 5. ./build_docker/./src/Storages/StorageURL.cpp:168: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae7f7ce 6. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae8b72e 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c5a1 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c31b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001ae952f6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:50.561208 [ 419 ] {052b5204-ed5e-426b-afc1-2f65e92660fa} executeQuery: Code: 507. DB::Exception: Sharding key cityHash64(key) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46496) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (query 53, line 148) (in query: -- analyzer does support this select * from dist_01756_str where key in ('0', Null) settings enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001aa80a89 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001aa7f201 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1160: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000018947ab6 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:920: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x000000001893be6c 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:930: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000189350eb 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001892fec6 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000018a165ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018a14a56 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000018a1a06d 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:50.568900 [ 419 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key cityHash64(key) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001aa80a89 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001aa7f201 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1160: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000018947ab6 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:920: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x000000001893be6c 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:930: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000189350eb 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001892fec6 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000018a165ca 11. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018a14a56 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000018a1a06d 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:51.283938 [ 419 ] {bb8e9d58-2072-4e83-8411-6ffba946454b} executeQuery: Code: 53. DB::Exception: Cannot convert string '255foo' to type UInt8. (TYPE_MISMATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46496) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (query 57, line 157) (in query: select * from dist_01756_column where dummy in (0, '255foo');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd7b5c 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000018dd8204 7. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000017f10008 8. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000017f0da99 9. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000017f1cdff 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x0000000017f1c871 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x0000000017f1c7b6 12. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982c4c 13. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 14. ./build_docker/./src/Planner/Planner.cpp:243: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000001897db88 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018979015 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:10:51.298759 [ 419 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '255foo' to type UInt8. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd7b5c 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000018dd8204 7. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000017f10008 8. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000017f0da99 9. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000017f1cdff 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x0000000017f1c871 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x0000000017f1c7b6 12. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982c4c 13. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 14. ./build_docker/./src/Planner/Planner.cpp:243: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000001897db88 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018979015 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:10:51.835747 [ 419 ] {9e1e1381-5f21-4f46-b7e5-b2e7b96c264e} executeQuery: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46496) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (query 60, line 163) (in query: select * from dist_01756 where dummy in (0, 2) settings optimize_skip_unused_shards_limit=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001aa80a89 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001aa7f201 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa413 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:10:51.841756 [ 419 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key intHash64(dummy) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001aa80a89 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001aa7f201 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa413 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:10:52.436013 [ 1859 ] {a3bea619-245c-4143-baaf-e662264e95ea} executeQuery: Code: 48. DB::Exception: Unknown compression method 'zip'. Only 'auto', 'none', 'gzip', 'deflate', 'br', 'xz', 'zstd', 'lz4', 'bz2', 'snappy' are supported as compression methods. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54918) (comment: 01030_storage_url_syntax.sql) (query 38, line 67) (in query: create table test_table_url(id UInt32) ENGINE = URL('http://localhost/endpoint', 'JSONEachRow', 'zip') ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/IO/CompressionMethod.cpp:118: DB::chooseCompressionMethod(String const&, String const&) @ 0x0000000010ef85f5 5. ./build_docker/./src/Storages/StorageURL.cpp:159: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae7f487 6. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae8b72e 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c5a1 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c31b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001ae952f6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:52.454796 [ 1859 ] {} TCPHandler: Code: 48. DB::Exception: Unknown compression method 'zip'. Only 'auto', 'none', 'gzip', 'deflate', 'br', 'xz', 'zstd', 'lz4', 'bz2', 'snappy' are supported as compression methods. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/IO/CompressionMethod.cpp:118: DB::chooseCompressionMethod(String const&, String const&) @ 0x0000000010ef85f5 5. ./build_docker/./src/Storages/StorageURL.cpp:159: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae7f487 6. ./build_docker/./src/Storages/StorageURL.cpp:1424: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x000000001ae8b72e 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageURL* std::construct_at[abi:ne190107], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c5a1 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, 0>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x000000001ae9c31b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001ae952f6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:53.475778 [ 1867 ] {234d6b2b-b777-4db4-a5bb-47036506b412} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.85 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56036) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 5000000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:10:53.482816 [ 1867 ] {234d6b2b-b777-4db4-a5bb-47036506b412} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.85 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:10:55.000853 [ 2053 ] {fcdcbeb9-9973-4a4a-8adf-37028d791eff} executeQuery: Code: 53. DB::Exception: Cannot convert string 'numbers1' to type UInt64. (TYPE_MISMATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41994) (comment: 00578_merge_table_shadow_virtual_column.sql) (query 5, line 7) (in query: SELECT count() FROM merge(currentDatabase(), '^numbers\\d+$') WHERE _table='numbers1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd7b5c 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6897d0 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6740a5 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000001c0b4ee0 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000001c321a81 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000001895e815 18. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898e9cd 19. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x00000000189866e7 20. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:10:55.026033 [ 2053 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'numbers1' to type UInt64. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd7b5c 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6897d0 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6740a5 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000001c0b4ee0 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000001c321a81 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000001895e815 18. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898e9cd 19. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x00000000189866e7 20. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:10:57.478255 [ 1861 ] {d1c84f72-1a79-476b-9381-b555e0f3d8ee} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime 2024-040: Cannot parse DateTime from String: In scope SELECT * FROM pv(timestamp_param = toDateTime('2024-040')). (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41992) (comment: 03146_parameterized_view_with_date.sql) (query 7, line 12) (in query: select * from pv (timestamp_param=toDateTime('2024-040'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000088dac80 4. ./build_docker/./src/IO/ReadHelpers.cpp:1518: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x0000000010c4c79b 5. ./src/IO/ReadHelpers.h:1113: void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x00000000140651fc 6. ./src/IO/ReadHelpers.h:1216: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016303980 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162f6854 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161df87c 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000162045f5 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016203a80 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4705: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8b9f3 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 2025.07.28 06:10:57.544036 [ 1861 ] {} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime 2024-040: Cannot parse DateTime from String: In scope SELECT * FROM pv(timestamp_param = toDateTime('2024-040')). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000088dac80 4. ./build_docker/./src/IO/ReadHelpers.cpp:1518: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x0000000010c4c79b 5. ./src/IO/ReadHelpers.h:1113: void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x00000000140651fc 6. ./src/IO/ReadHelpers.h:1216: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016303980 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162f6854 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161df87c 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000162045f5 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016203a80 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4705: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8b9f3 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 2025.07.28 06:10:58.316343 [ 2052 ] {0ac6fa8d-36e2-4d4d-b83c-86611f07badd} executeQuery: Code: 55. DB::Exception: Method write is not supported by storage Distributed with more than one shard and no sharding key provided. (STORAGE_REQUIRES_PARAMETER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42016) (comment: 01602_insert_into_table_function_cluster.sql) (query 7, line 11) (in query: -- More than one shard, sharding key is necessary INSERT INTO FUNCTION cluster('test_cluster_two_shards_localhost', currentDatabase(), x) SELECT * FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/StorageDistributed.cpp:944: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001aa86482 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:630: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001c1a4cf7 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000189146b7 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000018916a9a 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891929e 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:10:58.318830 [ 2052 ] {} TCPHandler: Code: 55. DB::Exception: Method write is not supported by storage Distributed with more than one shard and no sharding key provided. (STORAGE_REQUIRES_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/StorageDistributed.cpp:944: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001aa86482 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:630: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001c1a4cf7 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000189146b7 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000018916a9a 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891929e 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:10:58.718042 [ 2052 ] {ffeaf36a-6b00-4d74-bcc5-f65d0e2222b0} executeQuery: Code: 55. DB::Exception: Method write is not supported by storage Distributed with more than one shard and no sharding key provided. (STORAGE_REQUIRES_PARAMETER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42016) (comment: 01602_insert_into_table_function_cluster.sql) (query 9, line 15) (in query: INSERT INTO FUNCTION remote('127.0.0.{1,2}', currentDatabase(), y, '[HIDDEN]') SELECT * FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/StorageDistributed.cpp:944: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001aa86482 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:630: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001c1a4cf7 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000189146b7 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000018916a9a 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891929e 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:10:58.727914 [ 2052 ] {} TCPHandler: Code: 55. DB::Exception: Method write is not supported by storage Distributed with more than one shard and no sharding key provided. (STORAGE_REQUIRES_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/StorageDistributed.cpp:944: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001aa86482 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:630: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001c1a4cf7 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000189146b7 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000018916a9a 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891929e 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:11:04.209193 [ 2070 ] {30ad1dea-cf31-4af6-aafc-5d607f1c4330} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.85 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48350) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 5000000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:11:04.313079 [ 2070 ] {30ad1dea-cf31-4af6-aafc-5d607f1c4330} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.85 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:11:06.526928 [ 1867 ] {2887bf20-08fe-4512-b7a6-9fab46d10a29} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `t` in scope WITH t AS (SELECT 1) SELECT t, (SELECT * FROM t) FROM t. Maybe you meant: ['1']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60320) (comment: 03101_analyzer_identifiers_2.sql) (query 19, line 34) (in query: -- here we refer to table `test1` (defined as subquery) three times, one of them inside another scalar subquery. WITH t AS (SELECT 1) SELECT t, (SELECT * FROM t) FROM t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:11:06.528622 [ 1867 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `t` in scope WITH t AS (SELECT 1) SELECT t, (SELECT * FROM t) FROM t. Maybe you meant: ['1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:11:06.554108 [ 1867 ] {653c1dc5-d051-4a63-bb02-90860785ee8b} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x FROM (SELECT y FROM VALUES('y UInt16', 2) WHERE (1 AS x) = y) AS t. Maybe you meant: ['y']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60320) (comment: 03101_analyzer_identifiers_2.sql) (query 20, line 37) (in query: -- throws, because x is not visible outside. SELECT x FROM (SELECT y FROM VALUES ('y UInt16', (2)) WHERE (1 AS x) = y) AS t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:11:06.560371 [ 1867 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x FROM (SELECT y FROM VALUES('y UInt16', 2) WHERE (1 AS x) = y) AS t. Maybe you meant: ['y']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:11:06.581486 [ 1867 ] {a3124846-3c40-45ed-a481-d66091781ad0} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `t.x` in scope SELECT t.x FROM (SELECT * FROM (SELECT 1 AS x) AS t). (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60320) (comment: 03101_analyzer_identifiers_2.sql) (query 21, line 40) (in query: -- throws, because the table name `t` is not visible outside SELECT t.x FROM (SELECT * FROM (SELECT 1 AS x) AS t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:11:06.590450 [ 1867 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `t.x` in scope SELECT t.x FROM (SELECT * FROM (SELECT 1 AS x) AS t). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:11:06.930602 [ 1867 ] {98cfd6c6-191e-4b93-bce8-02c881c1039b} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test1.a` in scope SELECT test1.a FROM (SELECT a FROM test1) AS t. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60320) (comment: 03101_analyzer_identifiers_2.sql) (query 28, line 52) (in query: -- this is wrong, the `tbl` name is not exported SELECT test1.a FROM (SELECT a FROM test1) AS t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:11:06.931574 [ 1867 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `test1.a` in scope SELECT test1.a FROM (SELECT a FROM test1) AS t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:11:06.956649 [ 1867 ] {3c144a55-b1a8-4c7c-afef-add26e75295e} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `test1.a` in scope SELECT test1.a FROM (SELECT a FROM test1 AS t2) AS t. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60320) (comment: 03101_analyzer_identifiers_2.sql) (query 29, line 54) (in query: -- this is also wrong, the `t2` alias is not exported SELECT test1.a FROM (SELECT a FROM test1 AS t2) AS t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:11:06.959013 [ 1867 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `test1.a` in scope SELECT test1.a FROM (SELECT a FROM test1 AS t2) AS t. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:11:06.978928 [ 1867 ] {9c0f55ac-75cf-41c3-b5b3-55cede6e3419} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x, (SELECT 1 AS x). (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60320) (comment: 03101_analyzer_identifiers_2.sql) (query 30, line 58) (in query: -- does not work, `x` is not visible; SELECT x, (SELECT 1 AS x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:11:06.979967 [ 1867 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x, (SELECT 1 AS x). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:11:06.999605 [ 1867 ] {1f041acb-fe40-4bb9-8561-34e250f59101} executeQuery: Code: 47. DB::Exception: Unknown expression or table expression identifier `x` in scope SELECT x IN (SELECT 1 AS x). (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60320) (comment: 03101_analyzer_identifiers_2.sql) (query 31, line 60) (in query: -- does not work either; SELECT x IN (SELECT 1 AS x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:11:07.000751 [ 1867 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or table expression identifier `x` in scope SELECT x IN (SELECT 1 AS x). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:11:07.334505 [ 1867 ] {b7d3d3e6-52a8-41b8-9be0-be474e3254b4} executeQuery: Code: 179. DB::Exception: Multiple expressions 2 AS x and 1 AS x for alias x. In scope SELECT 1 AS x, 2 AS x. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60320) (comment: 03101_analyzer_identifiers_2.sql) (query 36, line 69) (in query: SELECT 1 AS x, 2 AS x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x0000000017ac5c74 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5736: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a80f5f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:11:07.335970 [ 1867 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions 2 AS x and 1 AS x for alias x. In scope SELECT 1 AS x, 2 AS x. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x0000000017ac5c74 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5736: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a80f5f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:11:07.496129 [ 1867 ] {175f0197-24de-43f4-aa44-5f2d897de8cb} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `y` in scope SELECT arrayMap(x -> [y * 2, x + 1 AS y, 1 AS z], [1, 2]), y. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60320) (comment: 03101_analyzer_identifiers_2.sql) (query 41, line 80) (in query: SELECT arrayMap(x -> [y * 2, (x + 1) AS y, 1 AS z], [1, 2]), y;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:11:07.497555 [ 1867 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `y` in scope SELECT arrayMap(x -> [y * 2, x + 1 AS y, 1 AS z], [1, 2]), y. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:11:07.600990 [ 1867 ] {8fb4bb52-e8b7-42b1-a8a5-e1d22db4334a} executeQuery: Code: 179. DB::Exception: Multiple expressions x -> concat(x, 'hello') AS y and x -> (x + 1) AS y for alias y. In scope SELECT arrayMap(x -> (x + 1) AS y, [3, 5]), arrayMap(x -> concat(x, 'hello') AS y, ['qq', 'ww']). (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60320) (comment: 03101_analyzer_identifiers_2.sql) (query 42, line 82) (in query: -- TODO: this must work --SELECT arrayMap(x -> [y * 2, (x + 1) AS y, 1 AS z], [1, 2]), z; SELECT arrayMap(x -> (x + 1) AS y, [3, 5]), arrayMap(x -> (x || 'hello') AS y, ['qq', 'ww']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x0000000017ac5c74 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5753: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a81111 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:11:07.602828 [ 1867 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions x -> concat(x, 'hello') AS y and x -> (x + 1) AS y for alias y. In scope SELECT arrayMap(x -> (x + 1) AS y, [3, 5]), arrayMap(x -> concat(x, 'hello') AS y, ['qq', 'ww']). (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x0000000017ac5c74 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5753: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a81111 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:11:07.976209 [ 1808 ] {48a0423a-6cb3-4458-8d56-4c6f4fa0147c} executeQuery: Code: 36. DB::Exception: Invalid time zone: Ðбырвалг. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53702) (comment: 02737_session_timezone.sql) (query 1, line 1) (in query: SET session_timezone = 'Ðбырвалг';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Core/SettingsFields.cpp:519: DB::SettingFieldTimezone::validateTimezone(String const&) @ 0x000000001739bb97 5. ./src/Core/SettingsFields.h:507: DB::SettingFieldTimezone::SettingFieldTimezone(DB::Field const&) @ 0x00000000172c17be 6. ./build_docker/./src/Core/Settings.cpp:6219: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda1657'(DB::Field const&)::__invoke(DB::Field const&) @ 0x000000001723b866 7. ./build_docker/./src/Core/Settings.cpp:6218: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x00000000172b8408 8. ./build_docker/./src/Core/Settings.cpp:6661: DB::Settings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x000000001713a371 9. ./build_docker/./src/Access/SettingsConstraints.cpp:245: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x0000000016e41af0 10. ./build_docker/./src/Access/SettingsConstraints.cpp:297: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff2f 11. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016e40223 12. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000181a89f6 13. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000018a200ec 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:11:07.977587 [ 1808 ] {} TCPHandler: Code: 36. DB::Exception: Invalid time zone: Ðбырвалг. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Core/SettingsFields.cpp:519: DB::SettingFieldTimezone::validateTimezone(String const&) @ 0x000000001739bb97 5. ./src/Core/SettingsFields.h:507: DB::SettingFieldTimezone::SettingFieldTimezone(DB::Field const&) @ 0x00000000172c17be 6. ./build_docker/./src/Core/Settings.cpp:6219: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda1657'(DB::Field const&)::__invoke(DB::Field const&) @ 0x000000001723b866 7. ./build_docker/./src/Core/Settings.cpp:6218: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x00000000172b8408 8. ./build_docker/./src/Core/Settings.cpp:6661: DB::Settings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x000000001713a371 9. ./build_docker/./src/Access/SettingsConstraints.cpp:245: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x0000000016e41af0 10. ./build_docker/./src/Access/SettingsConstraints.cpp:297: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff2f 11. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016e40223 12. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000181a89f6 13. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000018a200ec 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:11:09.242586 [ 2061 ] {88622ce9-16b3-4a66-8ace-6bed8cabf832} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.85 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51682) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 5000000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:11:09.256614 [ 2061 ] {88622ce9-16b3-4a66-8ace-6bed8cabf832} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.85 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000001741138c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fb59 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:11:11.018674 [ 2095 ] {e5e356cf-163f-4c43-ae61-d09b58a2e174} executeQuery: Code: 46. DB::Exception: Function with name `c23ount` does not exist. In scope SELECT c23ount(*) FROM system.functions. Maybe you meant: ['count']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53748) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select c23ount(*) from system.functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:11.020756 [ 2095 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `c23ount` does not exist. In scope SELECT c23ount(*) FROM system.functions. Maybe you meant: ['count']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:11.588794 [ 1859 ] {2a5e8719-1544-4837-958e-03706a529e41} executeQuery: Code: 46. DB::Exception: Function with name `cunt` does not exist. In scope SELECT cunt(*) FROM system.functions. Maybe you meant: ['count','cbrt']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53774) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select cunt(*) from system.functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:11.590439 [ 1859 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `cunt` does not exist. In scope SELECT cunt(*) FROM system.functions. Maybe you meant: ['count','cbrt']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:12.118971 [ 1861 ] {b1ac4589-bef0-4e32-a0fa-5d5fc00c7a93} executeQuery: Code: 46. DB::Exception: Function with name `positin` does not exist. In scope SELECT positin(*) FROM system.functions. Maybe you meant: ['position','notIn']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53818) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select positin(*) from system.functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:12.121268 [ 1861 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `positin` does not exist. In scope SELECT positin(*) FROM system.functions. Maybe you meant: ['position','notIn']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:12.717809 [ 1851 ] {e288b074-a58b-4f3e-9182-af924eb69115} executeQuery: Code: 46. DB::Exception: Function with name `POSITIO` does not exist. In scope SELECT POSITIO(*) FROM system.functions. Maybe you meant: ['position']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53836) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select POSITIO(*) from system.functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:12.719772 [ 1851 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `POSITIO` does not exist. In scope SELECT POSITIO(*) FROM system.functions. Maybe you meant: ['position']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:13.248834 [ 1856 ] {f071d259-3ecf-437c-9623-2c613af5376c} executeQuery: Code: 46. DB::Exception: Function with name `fount` does not exist. In scope SELECT fount(*) FROM system.functions. Maybe you meant: ['count','round']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53840) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select fount(*) from system.functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:13.252373 [ 1856 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `fount` does not exist. In scope SELECT fount(*) FROM system.functions. Maybe you meant: ['count','round']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:13.909618 [ 1856 ] {d775618b-c508-4193-969b-aec0ac846122} executeQuery: Code: 46. DB::Exception: Function with name `positin` does not exist. In scope SELECT positin(*) FROM system.functions. Maybe you meant: ['position','notIn']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53856) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select positin(*) from system.functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:13.913760 [ 1856 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `positin` does not exist. In scope SELECT positin(*) FROM system.functions. Maybe you meant: ['position','notIn']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:14.470384 [ 1808 ] {310a1478-4a37-4dfd-8fbc-a73f4bb8837d} executeQuery: Code: 46. DB::Exception: Function with name `pov` does not exist. In scope SELECT pov(*) FROM system.functions. Maybe you meant: ['pow']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53872) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select pov(*) from system.functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:14.472353 [ 1808 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `pov` does not exist. In scope SELECT pov(*) FROM system.functions. Maybe you meant: ['pow']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:14.990886 [ 2061 ] {53b01b64-1c1f-4742-8e7d-2b30c7856031} executeQuery: Code: 46. DB::Exception: Function with name `getColumnStructure` does not exist. In scope SELECT getColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53886) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select getColumnStructure('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:14.994694 [ 2061 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `getColumnStructure` does not exist. In scope SELECT getColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:15.567182 [ 2053 ] {e7176dc9-1ba1-4fa1-a755-1c3f5a540bbf} executeQuery: Code: 46. DB::Exception: Function with name `gutColumnStructure` does not exist. In scope SELECT gutColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53908) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select gutColumnStructure('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:15.568899 [ 2053 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `gutColumnStructure` does not exist. In scope SELECT gutColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:16.094453 [ 2064 ] {4c359eef-e239-445c-b7d7-3a1fd66d695a} executeQuery: Code: 46. DB::Exception: Function with name `gupColumnStructure` does not exist. In scope SELECT gupColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53928) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select gupColumnStructure('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:16.103224 [ 2064 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `gupColumnStructure` does not exist. In scope SELECT gupColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:16.709741 [ 2064 ] {7b09e94d-b181-4cb0-a1ff-a2cde2e276c0} executeQuery: Code: 46. DB::Exception: Function with name `provideColumnStructure` does not exist. In scope SELECT provideColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53936) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select provideColumnStructure('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:16.716857 [ 2064 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `provideColumnStructure` does not exist. In scope SELECT provideColumnStructure('abc'). Maybe you meant: ['dumpColumnStructure']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:17.287600 [ 1861 ] {4e55f67e-968e-4ea0-b094-29651b34d7e4} executeQuery: Code: 46. DB::Exception: Function with name `multisearchallposicionutf7` does not exist. In scope SELECT multisearchallposicionutf7('abc'). Maybe you meant: ['multiSearchAllPositionsUTF8','multiSearchAllPositions']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34098) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select multisearchallposicionutf7('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:17.298640 [ 1861 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `multisearchallposicionutf7` does not exist. In scope SELECT multisearchallposicionutf7('abc'). Maybe you meant: ['multiSearchAllPositionsUTF8','multiSearchAllPositions']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:17.860430 [ 1861 ] {ad3f06b9-a9ae-4ccf-a936-dd924e97ab1c} executeQuery: Code: 46. DB::Exception: Function with name `multisearchallposicionutf7casesensitive` does not exist. In scope SELECT multisearchallposicionutf7casesensitive('abc'). Maybe you meant: ['multiSearchAllPositionsCaseInsensitive','multiSearchAllPositionsCaseInsensitiveUTF8']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34100) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select multisearchallposicionutf7casesensitive('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:17.865441 [ 1861 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `multisearchallposicionutf7casesensitive` does not exist. In scope SELECT multisearchallposicionutf7casesensitive('abc'). Maybe you meant: ['multiSearchAllPositionsCaseInsensitive','multiSearchAllPositionsCaseInsensitiveUTF8']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:18.582815 [ 1867 ] {4ef7988d-e6d4-4a21-b33a-8786c1aeef9e} executeQuery: Code: 46. DB::Exception: Function with name `multiSearchAllposicionutf7sensitive` does not exist. In scope SELECT multiSearchAllposicionutf7sensitive('abc'). Maybe you meant: ['multiSearchAllPositionsCaseInsensitive','multiSearchAnyCaseInsensitive']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34108) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select multiSearchAllposicionutf7sensitive('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:18.590663 [ 1867 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `multiSearchAllposicionutf7sensitive` does not exist. In scope SELECT multiSearchAllposicionutf7sensitive('abc'). Maybe you meant: ['multiSearchAllPositionsCaseInsensitive','multiSearchAnyCaseInsensitive']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:19.132814 [ 1856 ] {8f354201-6c17-4cfa-b310-247e90a3c488} executeQuery: Code: 46. DB::Exception: Function with name `multiSearchAllPosicionSensitiveUTF8` does not exist. In scope SELECT multiSearchAllPosicionSensitiveUTF8('abc'). Maybe you meant: ['multiSearchAnyCaseInsensitiveUTF8','multiSearchAllPositionsCaseInsensitiveUTF8']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34116) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select multiSearchAllPosicionSensitiveUTF8('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:19.136268 [ 1856 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `multiSearchAllPosicionSensitiveUTF8` does not exist. In scope SELECT multiSearchAllPosicionSensitiveUTF8('abc'). Maybe you meant: ['multiSearchAnyCaseInsensitiveUTF8','multiSearchAllPositionsCaseInsensitiveUTF8']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aaa652 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:11:20.731085 [ 1856 ] {dd76981b-d21b-421f-8314-5d614e191768} executeQuery: Code: 46. DB::Exception: Unknown table function numberss. Maybe you meant: ['numbers','numbers_mt']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34124) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select * FROM numberss(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4742: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d801 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:20.737632 [ 1856 ] {} TCPHandler: Code: 46. DB::Exception: Unknown table function numberss. Maybe you meant: ['numbers','numbers_mt']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4742: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d801 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:21.435569 [ 2052 ] {6b7c52c9-4d5a-46f1-8aa2-1584b2299f82} executeQuery: Code: 46. DB::Exception: Unknown table function anothernumbers. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34158) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select * FROM anothernumbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4746: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d75f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:21.438699 [ 2052 ] {} TCPHandler: Code: 46. DB::Exception: Unknown table function anothernumbers. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4746: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d75f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:22.044003 [ 2061 ] {696d3505-502c-4f85-8883-06da3a02d151} executeQuery: Code: 46. DB::Exception: Unknown table function mynumbers. Maybe you meant: ['numbers']. (UNKNOWN_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34160) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: select * FROM mynumbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4742: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d801 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:22.045665 [ 2061 ] {} TCPHandler: Code: 46. DB::Exception: Unknown table function mynumbers. Maybe you meant: ['numbers']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4742: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d801 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:23.013940 [ 2061 ] {9384d9d8-c774-4200-9922-be0312ab35d4} executeQuery: Code: 56. DB::Exception: Unknown table engine MergeTre. Maybe you meant: ['MergeTree']. (UNKNOWN_STORAGE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34162) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: CREATE TABLE stored_aggregates (d Date, Uniq AggregateFunction(uniq, UInt64)) ENGINE = MergeTre(d, d, 8192);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000a1fa4c6 4. ./build_docker/./src/Storages/StorageFactory.cpp:172: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel, bool) const @ 0x000000001aab3a8b 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:11:23.019882 [ 2061 ] {} TCPHandler: Code: 56. DB::Exception: Unknown table engine MergeTre. Maybe you meant: ['MergeTree']. (UNKNOWN_STORAGE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000a1fa4c6 4. ./build_docker/./src/Storages/StorageFactory.cpp:172: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel, bool) const @ 0x000000001aab3a8b 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:11:23.670686 [ 1808 ] {49a2e966-a9cf-415f-b1af-4af32b96d8ed} executeQuery: Code: 50. DB::Exception: Unknown data type family: AgregateFunction. Maybe you meant: ['AggregateFunction']. (UNKNOWN_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34176) (comment: 00834_hints_for_type_function_typos.sh) (query 1, line 1) (in query: CREATE TABLE stored_aggregates (d Date, Uniq AgregateFunction(uniq, UInt64)) ENGINE = MergeTree(d, d, 8192);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:251: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x00000000174316cb 5. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:125: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000017430208 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:11:23.672679 [ 1808 ] {} TCPHandler: Code: 50. DB::Exception: Unknown data type family: AgregateFunction. Maybe you meant: ['AggregateFunction']. (UNKNOWN_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:251: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x00000000174316cb 5. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:125: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000017430208 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:11:24.651855 [ 1859 ] {9be406d0-0aec-45e3-bb83-6a8ca27624f5} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.11 MiB (attempt to allocate chunk of 1.11 MiB bytes), maximum: 1.00 B. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34202) (comment: 02028_create_select_settings.sql) (query 1, line 3) (in query: CREATE TABLE test_table ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 55509, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.817012369632721, replace_long_file_name_to_hash = false, max_file_name_length = 32, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 12631041, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 9412273, merge_max_block_size = 7319, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1819174543, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 5889084, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 94, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 33176, primary_key_compress_block_size = 53621, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true AS SELECT a_table.a, b_table.b_arr FROM (SELECT arrayJoin(range(10000)) AS a) AS a_table CROSS JOIN (SELECT range(10000) AS b_arr) AS b_table SETTINGS max_memory_usage = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. AllocatorWithMemoryTracking::allocate(unsigned long) @ 0x0000000009511032 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:305: std::vector>::reserve(unsigned long) @ 0x0000000013e3bcd5 10. ./build_docker/./src/Analyzer/Utils.cpp:1215: DB::(anonymous namespace)::getFieldFromColumnForASTLiteralImpl(COW::immutable_ptr const&, unsigned long, std::shared_ptr const&, bool) @ 0x00000000179aa4fc 11. ./build_docker/./src/Analyzer/Utils.cpp:1324: DB::getFieldFromColumnForASTLiteral(COW::immutable_ptr const&, unsigned long, std::shared_ptr const&) @ 0x00000000179a9654 12. ./build_docker/./src/Analyzer/ConstantNode.cpp:170: DB::ConstantNode::toASTImpl(DB::ConvertToASTOptions const&) const @ 0x000000001796afc0 13. ./build_docker/./src/Analyzer/IQueryTreeNode.cpp:339: DB::IQueryTreeNode::toAST(DB::ConvertToASTOptions const&) const @ 0x0000000017975730 14. ./build_docker/./src/Analyzer/ListNode.cpp:65: DB::ListNode::toASTImpl(DB::ConvertToASTOptions const&) const @ 0x000000001797d966 15. ./build_docker/./src/Analyzer/IQueryTreeNode.cpp:339: DB::IQueryTreeNode::toAST(DB::ConvertToASTOptions const&) const @ 0x0000000017975730 16. ./build_docker/./src/Analyzer/QueryNode.cpp:418: DB::QueryNode::toASTImpl(DB::ConvertToASTOptions const&) const @ 0x0000000017988625 17. ./build_docker/./src/Analyzer/IQueryTreeNode.cpp:339: DB::IQueryTreeNode::toAST(DB::ConvertToASTOptions const&) const @ 0x0000000017975730 18. ./build_docker/./src/Analyzer/Utils.cpp:362: DB::addTableExpressionOrJoinIntoTablesInSelectQuery(std::shared_ptr&, std::shared_ptr const&, DB::ConvertToASTOptions const&) @ 0x00000000179a0e53 19. ./build_docker/./src/Analyzer/JoinNode.cpp:219: DB::CrossJoinNode::toASTImpl(DB::ConvertToASTOptions const&) const @ 0x00000000179be30d 20. ./build_docker/./src/Analyzer/IQueryTreeNode.cpp:339: DB::IQueryTreeNode::toAST(DB::ConvertToASTOptions const&) const @ 0x0000000017975730 21. ./build_docker/./src/Analyzer/Utils.cpp:448: DB::addTableExpressionOrJoinIntoTablesInSelectQuery(std::shared_ptr&, std::shared_ptr const&, DB::ConvertToASTOptions const&) @ 0x00000000179a0eda 22. ./build_docker/./src/Analyzer/QueryNode.cpp:438: DB::QueryNode::toASTImpl(DB::ConvertToASTOptions const&) const @ 0x00000000179889c1 23. ./build_docker/./src/Analyzer/IQueryTreeNode.cpp:339: DB::IQueryTreeNode::toAST(DB::ConvertToASTOptions const&) const @ 0x0000000017975730 24. ./build_docker/./src/Planner/Utils.cpp:145: DB::queryNodeToSelectQuery(std::shared_ptr const&, bool) @ 0x0000000017a3b839 25. ./build_docker/./src/Planner/Utils.cpp:443: DB::buildSelectQueryInfo(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017a3df38 26. ./build_docker/./src/Planner/Planner.cpp:1843: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982015 27. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:230: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x000000001897b909 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:207: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897b7a1 30. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:957: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b9157 31. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 2025.07.28 06:11:24.656358 [ 1859 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.11 MiB (attempt to allocate chunk of 1.11 MiB bytes), maximum: 1.00 B. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. AllocatorWithMemoryTracking::allocate(unsigned long) @ 0x0000000009511032 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:305: std::vector>::reserve(unsigned long) @ 0x0000000013e3bcd5 10. ./build_docker/./src/Analyzer/Utils.cpp:1215: DB::(anonymous namespace)::getFieldFromColumnForASTLiteralImpl(COW::immutable_ptr const&, unsigned long, std::shared_ptr const&, bool) @ 0x00000000179aa4fc 11. ./build_docker/./src/Analyzer/Utils.cpp:1324: DB::getFieldFromColumnForASTLiteral(COW::immutable_ptr const&, unsigned long, std::shared_ptr const&) @ 0x00000000179a9654 12. ./build_docker/./src/Analyzer/ConstantNode.cpp:170: DB::ConstantNode::toASTImpl(DB::ConvertToASTOptions const&) const @ 0x000000001796afc0 13. ./build_docker/./src/Analyzer/IQueryTreeNode.cpp:339: DB::IQueryTreeNode::toAST(DB::ConvertToASTOptions const&) const @ 0x0000000017975730 14. ./build_docker/./src/Analyzer/ListNode.cpp:65: DB::ListNode::toASTImpl(DB::ConvertToASTOptions const&) const @ 0x000000001797d966 15. ./build_docker/./src/Analyzer/IQueryTreeNode.cpp:339: DB::IQueryTreeNode::toAST(DB::ConvertToASTOptions const&) const @ 0x0000000017975730 16. ./build_docker/./src/Analyzer/QueryNode.cpp:418: DB::QueryNode::toASTImpl(DB::ConvertToASTOptions const&) const @ 0x0000000017988625 17. ./build_docker/./src/Analyzer/IQueryTreeNode.cpp:339: DB::IQueryTreeNode::toAST(DB::ConvertToASTOptions const&) const @ 0x0000000017975730 18. ./build_docker/./src/Analyzer/Utils.cpp:362: DB::addTableExpressionOrJoinIntoTablesInSelectQuery(std::shared_ptr&, std::shared_ptr const&, DB::ConvertToASTOptions const&) @ 0x00000000179a0e53 19. ./build_docker/./src/Analyzer/JoinNode.cpp:219: DB::CrossJoinNode::toASTImpl(DB::ConvertToASTOptions const&) const @ 0x00000000179be30d 20. ./build_docker/./src/Analyzer/IQueryTreeNode.cpp:339: DB::IQueryTreeNode::toAST(DB::ConvertToASTOptions const&) const @ 0x0000000017975730 21. ./build_docker/./src/Analyzer/Utils.cpp:448: DB::addTableExpressionOrJoinIntoTablesInSelectQuery(std::shared_ptr&, std::shared_ptr const&, DB::ConvertToASTOptions const&) @ 0x00000000179a0eda 22. ./build_docker/./src/Analyzer/QueryNode.cpp:438: DB::QueryNode::toASTImpl(DB::ConvertToASTOptions const&) const @ 0x00000000179889c1 23. ./build_docker/./src/Analyzer/IQueryTreeNode.cpp:339: DB::IQueryTreeNode::toAST(DB::ConvertToASTOptions const&) const @ 0x0000000017975730 24. ./build_docker/./src/Planner/Utils.cpp:145: DB::queryNodeToSelectQuery(std::shared_ptr const&, bool) @ 0x0000000017a3b839 25. ./build_docker/./src/Planner/Utils.cpp:443: DB::buildSelectQueryInfo(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017a3df38 26. ./build_docker/./src/Planner/Planner.cpp:1843: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982015 27. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:230: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x000000001897b909 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:207: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897b7a1 30. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:957: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b9157 31. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 2025.07.28 06:11:24.867390 [ 1808 ] {60a84c98-ea7b-4277-9018-0e22126d06c3} executeQuery: Code: 182. DB::Exception: Table expression test_kbnlsjf4.m AS __table1 does not support column __table1.f in PREWHERE. In query SELECT * FROM m PREWHERE f = 1 ORDER BY a ASC. (ILLEGAL_PREWHERE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34186) (comment: 02575_merge_prewhere_ephemeral.sql) (query 10, line 36) (in query: SELECT * FROM m PREWHERE f = 1 ORDER BY a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f1942d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f19165 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f19165 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000017f1616b 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x000000001898327c 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:11:24.871353 [ 1808 ] {} TCPHandler: Code: 182. DB::Exception: Table expression test_kbnlsjf4.m AS __table1 does not support column __table1.f in PREWHERE. In query SELECT * FROM m PREWHERE f = 1 ORDER BY a ASC. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f1942d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f19165 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f19165 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000017f1616b 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x000000001898327c 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:11:28.807456 [ 2070 ] {51ddb494-22b6-4bb4-a3ac-c59d03e87c66} executeQuery: Code: 44. DB::Exception: Column of type FixedString is not supported by soundex function: In scope SELECT soundex(toFixedString('Smith', 5)). (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51468) (comment: 02711_soundex_function.sql) (query 20, line 26) (in query: -- negative tests SELECT soundex(toFixedString('Smith', 5));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::SoundexImpl::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000ec5010f 5. DB::FunctionStringToString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec4f923 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:11:28.811486 [ 2070 ] {} TCPHandler: Code: 44. DB::Exception: Column of type FixedString is not supported by soundex function: In scope SELECT soundex(toFixedString('Smith', 5)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::SoundexImpl::vectorFixed(DB::PODArray, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000ec5010f 5. DB::FunctionStringToString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec4f923 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:11:29.003035 [ 2070 ] {6aa465eb-52b7-4187-9326-e3a219225edf} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function soundex: In scope SELECT soundex(5). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51468) (comment: 02711_soundex_function.sql) (query 21, line 28) (in query: SELECT soundex(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionStringToString::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ec4fcd4 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:11:29.004136 [ 2070 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function soundex: In scope SELECT soundex(5). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionStringToString::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ec4fcd4 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:11:29.989631 [ 1856 ] {6b1ce2eb-a8ae-4cbe-8ee4-a2b5ca4e9800} executeQuery: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function greatest: In scope SELECT least(toUInt32(0), toInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51518) (comment: 01440_big_int_least_greatest.sql) (query 7, line 33) (in query: SELECT least(toUInt32(0), toInt256(0)), greatest(toInt32(0), toUInt256(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b919af3 5. DB::FunctionBinaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b6d84b6 6. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)1, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b6d74b7 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000090496a4 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:11:29.991126 [ 1856 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function greatest: In scope SELECT least(toUInt32(0), toInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b919af3 5. DB::FunctionBinaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b6d84b6 6. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)1, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b6d74b7 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000090496a4 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:11:30.128710 [ 1856 ] {2b173a31-ccce-468f-977a-2fecbc0b3a11} executeQuery: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function least: In scope SELECT least(toInt32(0), toUInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51518) (comment: 01440_big_int_least_greatest.sql) (query 8, line 34) (in query: SELECT least(toInt32(0), toUInt256(0)), greatest(toInt32(0), toUInt256(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c363773 5. DB::FunctionBinaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c121c16 6. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)0, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c120e97 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000090496a4 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:11:30.130303 [ 1856 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function least: In scope SELECT least(toInt32(0), toUInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c363773 5. DB::FunctionBinaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c121c16 6. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)0, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c120e97 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000090496a4 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:11:33.000156 [ 1865 ] {a8bd24bb-d725-47f4-8321-bcdd297ff2f6} executeQuery: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, 1.3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51638) (comment: 02008_tuple_to_name_value_pairs.sql) (query 12, line 22) (in query: SELECT tupleToNameValuePairs(tuple(1, 1.3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x000000000efa10ab 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:11:33.001912 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, 1.3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x000000000efa10ab 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:11:33.009745 [ 1865 ] {27c12300-89dd-4672-a2c7-e9b9e734ce24} executeQuery: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, [1, 2])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51638) (comment: 02008_tuple_to_name_value_pairs.sql) (query 13, line 23) (in query: SELECT tupleToNameValuePairs(tuple(1, [1,2]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x000000000efa10ab 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:11:33.011697 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, [1, 2])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x000000000efa10ab 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:11:33.023266 [ 1865 ] {70a336c6-d11f-430c-add7-67c76ef5d452} executeQuery: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, 'a')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51638) (comment: 02008_tuple_to_name_value_pairs.sql) (query 14, line 24) (in query: SELECT tupleToNameValuePairs(tuple(1, 'a'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x000000000efa10ab 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:11:33.026582 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: The argument tuple for function tupleToNameValuePairs must contain just one type.: In scope SELECT tupleToNameValuePairs((1, 'a')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x000000000efa10ab 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:11:33.224309 [ 1865 ] {cbe0672c-6228-4f8a-920c-b3f7da23eba4} executeQuery: Code: 43. DB::Exception: First argument for function tupleToNameValuePairs must be a tuple.: In scope SELECT tupleToNameValuePairs(33). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51638) (comment: 02008_tuple_to_name_value_pairs.sql) (query 15, line 25) (in query: SELECT tupleToNameValuePairs(33);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x000000000efa0e42 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:11:33.226202 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleToNameValuePairs must be a tuple.: In scope SELECT tupleToNameValuePairs(33). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTupleToNameValuePairs::getReturnTypeImpl(std::vector> const&) const @ 0x000000000efa0e42 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:11:38.073405 [ 2070 ] {543e248d-0ef7-4556-b652-60465f107ed3} executeQuery: Code: 475. DB::Exception: Value of step is to low (3600 seconds). Must be >= 1 day. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53628) (comment: 02112_with_fill_interval.sql) (query 15, line 21) (in query: SELECT d, count() FROM with_fill_date GROUP BY d ORDER BY d WITH FILL STEP INTERVAL 1 HOUR LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x000000001aa9f4e0 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:85: DB::getStepFunction(DB::Field const&, std::optional const&, std::shared_ptr const&) @ 0x000000001c316fab 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:203: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001c30effe 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001c30af36 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173aab0f 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173aa83d 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173c62ad 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c30a073 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3285b4 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:38.075258 [ 2070 ] {} TCPHandler: Code: 475. DB::Exception: Value of step is to low (3600 seconds). Must be >= 1 day. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x000000001aa9f4e0 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:85: DB::getStepFunction(DB::Field const&, std::optional const&, std::shared_ptr const&) @ 0x000000001c316fab 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:203: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001c30effe 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001c30af36 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173aab0f 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173aa83d 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173c62ad 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c30a073 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3285b4 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:38.310404 [ 2070 ] {a913f484-0155-47f9-ac5b-3b831f8dbe61} executeQuery: Code: 475. DB::Exception: Value of step is to low (3600 seconds). Must be >= 1 day. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53628) (comment: 02112_with_fill_interval.sql) (query 24, line 35) (in query: SELECT d, count() FROM with_fill_date GROUP BY d ORDER BY d WITH FILL STEP INTERVAL 1 HOUR LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x000000001aa9f4e0 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:85: DB::getStepFunction(DB::Field const&, std::optional const&, std::shared_ptr const&) @ 0x000000001c316fab 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:203: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001c30effe 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001c30af36 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173aab0f 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173aa83d 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173c62ad 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c30a073 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3285b4 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:38.314635 [ 2070 ] {} TCPHandler: Code: 475. DB::Exception: Value of step is to low (3600 seconds). Must be >= 1 day. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x000000001aa9f4e0 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:85: DB::getStepFunction(DB::Field const&, std::optional const&, std::shared_ptr const&) @ 0x000000001c316fab 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:203: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001c30effe 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001c30af36 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173aab0f 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173aa83d 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173c62ad 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c30a073 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3285b4 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:38.811638 [ 2070 ] {c153a43d-3407-466b-9b3a-cef7d161e14b} executeQuery: Code: 475. DB::Exception: STEP of Interval type can be used only with Date/DateTime types, but got UInt64. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53628) (comment: 02112_with_fill_interval.sql) (query 43, line 61) (in query: SELECT number FROM numbers(100) ORDER BY number WITH FILL STEP INTERVAL 1 HOUR;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:118: DB::getStepFunction(DB::Field const&, std::optional const&, std::shared_ptr const&) @ 0x000000001c316f0f 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:203: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001c30effe 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001c30af36 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173aab0f 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173aa83d 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173c62ad 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c30a073 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3285b4 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:38.814137 [ 2070 ] {} TCPHandler: Code: 475. DB::Exception: STEP of Interval type can be used only with Date/DateTime types, but got UInt64. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:118: DB::getStepFunction(DB::Field const&, std::optional const&, std::shared_ptr const&) @ 0x000000001c316f0f 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:203: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001c30effe 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001c30af36 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173aab0f 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173aa83d 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173c62ad 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c30a073 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3285b4 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:40.704989 [ 2062 ] {522fec19-f4fb-449e-b0b2-4b98597bbba6} executeQuery: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of recursive_cte AS (SELECT materialize(toUInt8(1)) AS n UNION ALL SELECT materialize(toUInt8(n + 1)) FROM recursive_cte WHERE n < 10). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53722) (comment: 03033_recursive_cte_basic.sql) (query 16, line 40) (in query: WITH RECURSIVE recursive_cte AS (SELECT materialize(toUInt8(1)) AS n UNION ALL SELECT materialize(toUInt8(n + 1)) FROM recursive_cte WHERE n < 10) SELECT n FROM recursive_cte FORMAT Null SETTINGS max_recursive_cte_evaluation_depth = 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000aaf2986 4. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x000000001c437b72 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000001c434f05 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x000000001c434af1 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:11:40.709464 [ 2062 ] {} TCPHandler: Code: 306. DB::Exception: Maximum recursive CTE evaluation depth (5) exceeded, during evaluation of recursive_cte AS (SELECT materialize(toUInt8(1)) AS n UNION ALL SELECT materialize(toUInt8(n + 1)) FROM recursive_cte WHERE n < 10). Consider raising max_recursive_cte_evaluation_depth setting.: While executing RecursiveCTESource. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000aaf2986 4. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:172: DB::RecursiveCTEChunkGenerator::buildStepExecutor() @ 0x000000001c437b72 5. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:132: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000001c434f05 6. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:264: DB::RecursiveCTESource::generate() @ 0x000000001c434af1 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:11:40.943361 [ 1856 ] {0d0c3748-87c9-45dc-b586-b8f71849b747} executeQuery: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53772) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (query 7, line 23) (in query: INSERT INTO r1 VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000018fabeec 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:256: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001b779690 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001b77787d 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000001b76241b 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001b75ea7e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:40.944765 [ 1856 ] {} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000018fabeec 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:256: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001b779690 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001b77787d 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000001b76241b 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001b75ea7e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:40.960217 [ 1856 ] {79c8bcb3-ebc3-4665-9970-41ea1ee9112b} executeQuery: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53772) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (query 8, line 25) (in query: -- retry should still fail despite the insert_deduplicate enabled INSERT INTO r1 VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000018fabeec 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:256: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001b779690 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001b77787d 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000001b76241b 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001b75ea7e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:40.961734 [ 1856 ] {} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000018fabeec 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:256: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001b779690 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001b77787d 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000001b76241b 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001b75ea7e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:40.979758 [ 1856 ] {c2808013-8270-465f-a12c-ce22df336f43} executeQuery: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53772) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (query 9, line 27) (in query: INSERT INTO r1 VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000018fabeec 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:256: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001b779690 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001b77787d 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000001b76241b 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001b75ea7e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:40.981103 [ 1856 ] {} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000018fabeec 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:256: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001b779690 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001b77787d 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000001b76241b 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001b75ea7e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:41.160295 [ 1856 ] {b5aa25f5-bc66-4363-a2a9-ce2636606a3c} executeQuery: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53772) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (query 16, line 39) (in query: INSERT INTO r1 VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000018fabeec 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:256: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001b779690 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001b77787d 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000001b76241b 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001b75ea7e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:41.161530 [ 1856 ] {} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000018fabeec 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:256: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001b779690 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001b77787d 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000001b76241b 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001b75ea7e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:41.182816 [ 1856 ] {d2a62886-20a1-4cac-aec7-c8cbe797b01a} executeQuery: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53772) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (query 17, line 41) (in query: -- retry should fail despite the insert_deduplicate enabled INSERT INTO r1 VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000018fabeec 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:256: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001b779690 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001b77787d 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000001b76241b 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001b75ea7e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:41.184498 [ 1856 ] {} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000018fabeec 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:256: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001b779690 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001b77787d 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000001b76241b 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001b75ea7e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:41.203147 [ 1856 ] {3f9c4db4-79bc-4837-b402-c277d9d140b9} executeQuery: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53772) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (query 18, line 43) (in query: INSERT INTO r1 VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000018fabeec 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:256: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001b779690 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001b77787d 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000001b76241b 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001b75ea7e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:41.204733 [ 1856 ] {} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (1) is less than requested quorum (2/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000018fabeec 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:256: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001b779690 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001b77787d 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000001b76241b 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001b75ea7e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:41.747656 [ 1856 ] {1e8922b9-263f-4914-9bff-21aa32cb992a} executeQuery: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53772) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (query 35, line 71) (in query: INSERT INTO r1 VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000018fabeec 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:256: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001b779690 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001b77787d 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000001b76241b 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001b75ea7e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:41.748853 [ 1856 ] {} TCPHandler: Code: 285. DB::Exception: Number of alive replicas (2) is less than requested quorum (3/2). (TOO_FEW_LIVE_REPLICAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, unsigned long&, unsigned long&) @ 0x0000000018fabeec 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:256: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001b779690 5. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001b77787d 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x000000001b76241b 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000001b75ea7e 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:42.385690 [ 1856 ] {c140aa32-7beb-4049-bd9d-c85769bd971d} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53772) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (query 42, line 83) (in query: INSERT INTO r1 SETTINGS insert_keeper_fault_injection_probability=0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000001b766268 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000001b7825a8 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000001b763b7c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001b751338 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000001b76288f 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0891 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afd01 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:42.407032 [ 1856 ] {} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000001b766268 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000001b7825a8 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000001b763b7c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001b751338 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000001b76288f 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0891 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afd01 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:42.457567 [ 1856 ] {fb44ce90-edf7-41c7-9fc9-b82afd55ec10} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53772) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (query 43, line 85) (in query: -- retry should fail despite the insert_deduplicate enabled INSERT INTO r1 SETTINGS insert_keeper_fault_injection_probability=0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000001b766268 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000001b7825a8 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000001b763b7c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001b751338 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000001b76288f 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0891 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afd01 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:42.463810 [ 1856 ] {} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000001b766268 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000001b7825a8 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000001b763b7c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001b751338 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000001b76288f 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0891 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afd01 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:42.490768 [ 1856 ] {c7d40b1a-de3c-48cd-8793-411a4ad689f3} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53772) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (query 44, line 87) (in query: INSERT INTO r1 SETTINGS insert_keeper_fault_injection_probability=0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000001b766268 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000001b7825a8 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000001b763b7c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001b751338 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000001b76288f 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0891 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afd01 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:42.496264 [ 1856 ] {} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000001b766268 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000001b7825a8 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000001b763b7c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001b751338 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000001b76288f 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0891 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afd01 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:11:42.530709 [ 2053 ] {7d8a7246-690e-4436-88e3-68f63b473f7f} executeQuery: Code: 47. DB::Exception: Unknown column: col_sq, there are only columns col. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53828) (comment: 03355_issue_31183.sql) (query 6, line 12) (in query: SELECT t1.col, t1.col_sq FROM test2 t2 LEFT JOIN test1 t1 ON t1.col = t2.col SETTINGS enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1244: DB::ActionsDAG::project(std::vector, std::allocator>> const&) @ 0x00000000179d8cc7 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1828: DB::SelectQueryExpressionAnalyzer::appendProjectResult(DB::ExpressionActionsChain&) const @ 0x0000000018330955 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2269: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x00000000183366e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1180: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000018947b86 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:920: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x000000001893be6c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:930: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000189350eb 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001892fec6 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000018a165ca 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018a14a56 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000018e3e32f 14. ./build_docker/./src/Interpreters/interpretSubquery.cpp:53: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000018e3d387 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1103: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000018324417 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x00000000183228a8 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000001833345f 18. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1180: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000018947b86 19. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:920: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x000000001893be6c 20. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:930: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000189350eb 21. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001892fec6 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000018a165ca 23. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018a14a56 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000018a1a06d 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:11:42.532552 [ 2053 ] {} TCPHandler: Code: 47. DB::Exception: Unknown column: col_sq, there are only columns col. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1244: DB::ActionsDAG::project(std::vector, std::allocator>> const&) @ 0x00000000179d8cc7 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1828: DB::SelectQueryExpressionAnalyzer::appendProjectResult(DB::ExpressionActionsChain&) const @ 0x0000000018330955 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2269: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x00000000183366e8 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1180: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000018947b86 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:920: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x000000001893be6c 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:930: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000189350eb 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001892fec6 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000018a165ca 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018a14a56 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000018e3e32f 14. ./build_docker/./src/Interpreters/interpretSubquery.cpp:53: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000018e3d387 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1103: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000018324417 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x00000000183228a8 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000001833345f 18. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1180: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000018947b86 19. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:920: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x000000001893be6c 20. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:930: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000189350eb 21. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001892fec6 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000018a165ca 23. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018a14a56 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000018a1a06d 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:11:48.920861 [ 1414 ] {e9344024-e525-46d2-b2d3-ca5afe71209f} BackupsWorker: Failed to make backup Disk('backups', '03315_query_log_privileges_backup_restore_test_9h6bm6w5'): Code: 497. DB::Exception: u_03315_query_log_test_9h6bm6w5: Not enough privileges. To execute this query, it's necessary to have the grant BACKUP ON test_9h6bm6w5.d_03315_query_log. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36a23 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, String const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d34fb7 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d342ab 7. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 8. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 9. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 10. ./build_docker/./src/Backups/BackupsWorker.cpp:554: DB::BackupsWorker::doBackup(std::shared_ptr, std::shared_ptr const&, String const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x0000000016ecce60 11. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x0000000016ede5ae 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000016ed7ccd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001686e1a3 14. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000001686e495 15. ./src/Common/threadPoolCallbackRunner.h:52: void std::__function::__policy_invoker::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001686e3cd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000001686d565 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000001686d245 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016ecad56 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x0000000016ecaafa 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x0000000018eb3a22 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:11:48.921491 [ 1414 ] {e9344024-e525-46d2-b2d3-ca5afe71209f} BackupImpl: An error happened, the backup won't be completed 2025.07.28 06:11:48.927664 [ 1808 ] {e9344024-e525-46d2-b2d3-ca5afe71209f} executeQuery: Code: 497. DB::Exception: u_03315_query_log_test_9h6bm6w5: Not enough privileges. To execute this query, it's necessary to have the grant BACKUP ON test_9h6bm6w5.d_03315_query_log. (ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37580) (comment: 03315_query_log_privileges_backup_restore.sh) (query 1, line 1) (in query: backup table d_03315_query_log to Disk('backups', '03315_query_log_privileges_backup_restore_test_9h6bm6w5')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36a23 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, String const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d34fb7 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d342ab 7. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 8. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 9. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 10. ./build_docker/./src/Backups/BackupsWorker.cpp:554: DB::BackupsWorker::doBackup(std::shared_ptr, std::shared_ptr const&, String const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x0000000016ecce60 11. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x0000000016ede5ae 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000016ed7ccd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001686e1a3 14. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000001686e495 15. ./src/Common/threadPoolCallbackRunner.h:52: void std::__function::__policy_invoker::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001686e3cd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:11:48.930133 [ 1808 ] {} TCPHandler: Code: 497. DB::Exception: u_03315_query_log_test_9h6bm6w5: Not enough privileges. To execute this query, it's necessary to have the grant BACKUP ON test_9h6bm6w5.d_03315_query_log. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36a23 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, String const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d34fb7 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d342ab 7. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 8. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 9. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 10. ./build_docker/./src/Backups/BackupsWorker.cpp:554: DB::BackupsWorker::doBackup(std::shared_ptr, std::shared_ptr const&, String const&, DB::BackupSettings const&, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x0000000016ecce60 11. ./build_docker/./src/Backups/BackupsWorker.cpp:418: DB::BackupsWorker::BackupStarter::doBackup() @ 0x0000000016ede5ae 12. ./build_docker/./src/Backups/BackupsWorker.cpp:488: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000016ed7ccd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001686e1a3 14. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000001686e495 15. ./src/Common/threadPoolCallbackRunner.h:52: void std::__function::__policy_invoker::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001686e3cd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000001686d565 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000001686d245 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016ecad56 7. ./build_docker/./src/Backups/BackupsWorker.cpp:334: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x0000000016ecaafa 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x0000000018eb3a22 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:11:50.953604 [ 2062 ] {1ac7e6a0-5749-44cc-9a54-3cb49dbbff17} executeQuery: Code: 1. DB::Exception: Expected function, got: x. (UNSUPPORTED_METHOD) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37722) (comment: 02292_create_function_validate.sql) (query 1, line 1) (in query: create function foo as x -- { serverError UNSUPPORTED_METHOD } ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:55: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x000000001c4d9a53 5. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x000000001c4da531 6. ./build_docker/./src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000018eab2ed 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:11:50.954592 [ 2062 ] {} TCPHandler: Code: 1. DB::Exception: Expected function, got: x. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:55: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x000000001c4d9a53 5. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x000000001c4da531 6. ./build_docker/./src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000018eab2ed 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:11:51.500610 [ 2062 ] {ca66cd64-586d-4859-825b-71ee2690e902} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 0, should be 2: In scope SELECT extractGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37752) (comment: 01273_extractGroups.sql) (query 1, line 1) (in query: -- error cases SELECT extractGroups();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:11:51.502116 [ 2062 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 0, should be 2: In scope SELECT extractGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:11:51.510598 [ 2062 ] {3fa9ad10-c684-4491-b800-7719de192bb2} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 1, should be 2: In scope SELECT extractGroups('hello'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37752) (comment: 01273_extractGroups.sql) (query 2, line 3) (in query: SELECT extractGroups('hello');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:11:51.511994 [ 2062 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 1, should be 2: In scope SELECT extractGroups('hello'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:11:51.695194 [ 2062 ] {38cc5b90-f1fa-409d-9bc5-fe3981f2b82a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractGroups'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractGroups('hello', 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37752) (comment: 01273_extractGroups.sql) (query 3, line 4) (in query: SELECT extractGroups('hello', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::(anonymous namespace)::FunctionExtractGroups::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aaf69c4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:11:51.697104 [ 2062 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractGroups'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractGroups('hello', 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::(anonymous namespace)::FunctionExtractGroups::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aaf69c4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:11:51.706141 [ 2062 ] {ddcb442c-2fa3-4db7-9587-e7ab5de549b8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractGroups'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractGroups(123, 'world'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37752) (comment: 01273_extractGroups.sql) (query 4, line 5) (in query: SELECT extractGroups(123, 'world');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::(anonymous namespace)::FunctionExtractGroups::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aaf69c4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:11:51.707621 [ 2062 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractGroups'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractGroups(123, 'world'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::(anonymous namespace)::FunctionExtractGroups::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aaf69c4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:11:51.906681 [ 2062 ] {cfe6ecfb-ac8c-430d-97aa-c572226bccf2} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (((, error: missing ): (((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT extractGroups('hello world', '((('). (CANNOT_COMPILE_REGEXP) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37752) (comment: 01273_extractGroups.sql) (query 5, line 6) (in query: SELECT extractGroups('hello world', '(((');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000087ec0e6 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000010bbf7d7 5. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf5d0b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:11:51.908332 [ 2062 ] {} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (((, error: missing ): (((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT extractGroups('hello world', '((('). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000087ec0e6 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000010bbf7d7 5. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf5d0b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:11:51.917359 [ 2062 ] {e3cc42ef-64d9-4b51-98d0-9f988220dc1c} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractGroups'. Expected: const String or const FixedString, got: String: In scope SELECT extractGroups('hello world', materialize('\\w+')). (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37752) (comment: 01273_extractGroups.sql) (query 6, line 7) (in query: SELECT extractGroups('hello world', materialize('\\w+'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::(anonymous namespace)::FunctionExtractGroups::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aaf69c4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:11:51.918796 [ 2062 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractGroups'. Expected: const String or const FixedString, got: String: In scope SELECT extractGroups('hello world', materialize('\\w+')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::(anonymous namespace)::FunctionExtractGroups::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aaf69c4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:11:52.522620 [ 2062 ] {f45d78bd-7551-411b-bd8f-0f9817435173} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: \w+: In scope SELECT extractGroups('hello world', '\\w+'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37752) (comment: 01273_extractGroups.sql) (query 8, line 10) (in query: SELECT extractGroups('hello world', '\\w+');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf6697 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:11:52.532975 [ 2062 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: \w+: In scope SELECT extractGroups('hello world', '\\w+'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf6697 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:11:55.597833 [ 2095 ] {f5c38640-ff58-47f0-b9d9-8b4e9d1e1fef} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22+01:02:03' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22+01:02:03'). (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37898) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 13, line 20) (in query: SELECT toDate('2022-08-22+01:02:03');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c4115 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:55.599538 [ 2095 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22+01:02:03' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22+01:02:03'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c4115 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:55.996270 [ 2095 ] {d08d03a3-63a3-4109-bc91-18b46e29b28c} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22+01:02:03' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22+01:02:03'). (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37898) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 14, line 21) (in query: SELECT toDate32('2022-08-22+01:02:03');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162d6c75 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162cbf14 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161def3c 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016202307 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000162018a0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.000173 [ 2095 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22+01:02:03' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22+01:02:03'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162d6c75 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162cbf14 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161def3c 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016202307 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000162018a0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.014198 [ 2095 ] {efe63db0-f4c2-467e-81bd-58d12debf505} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:0' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22 01:02:0'). (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37898) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 15, line 23) (in query: SELECT toDate('2022-08-22 01:02:0');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c4115 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.015350 [ 2095 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:0' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22 01:02:0'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c4115 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.027752 [ 2095 ] {6fed159d-217c-46be-9757-3bc6eb8032fc} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:0' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22 01:02:0'). (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37898) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 16, line 24) (in query: SELECT toDate32('2022-08-22 01:02:0');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162d6c75 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162cbf14 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161def3c 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016202307 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000162018a0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.029296 [ 2095 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:0' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22 01:02:0'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162d6c75 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162cbf14 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161def3c 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016202307 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000162018a0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.039328 [ 2095 ] {f8c6f2c9-1274-4f19-a217-19a56b98fc9c} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22 01:02:03.'). (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37898) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 17, line 26) (in query: SELECT toDate('2022-08-22 01:02:03.');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c4115 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.040325 [ 2095 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.' as Date: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate('2022-08-22 01:02:03.'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c4115 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.051794 [ 2095 ] {5dc6f6f0-926a-4d96-9165-508032879f15} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22 01:02:03.'). (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37898) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 18, line 27) (in query: SELECT toDate32('2022-08-22 01:02:03.');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162d6c75 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162cbf14 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161def3c 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016202307 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000162018a0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.052896 [ 2095 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.' as Date32: syntax error at position 10 (parsed just '2022-08-22'): In scope SELECT toDate32('2022-08-22 01:02:03.'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162d6c75 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162cbf14 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161def3c 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016202307 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000162018a0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.061814 [ 2095 ] {d367f1f9-c09c-42a7-be19-3eb8913e3bc2} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.111a' as Date: syntax error at position 23 (parsed just '2022-08-22 01:02:03.111'): In scope SELECT toDate('2022-08-22 01:02:03.111a'). (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37898) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 19, line 29) (in query: SELECT toDate('2022-08-22 01:02:03.111a');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c4115 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.062944 [ 2095 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.111a' as Date: syntax error at position 23 (parsed just '2022-08-22 01:02:03.111'): In scope SELECT toDate('2022-08-22 01:02:03.111a'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c4115 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.079845 [ 2095 ] {b95911f9-ae8d-4d5d-a33a-aeed3c7c36b1} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.2b' as Date32: syntax error at position 21 (parsed just '2022-08-22 01:02:03.2'): In scope SELECT toDate32('2022-08-22 01:02:03.2b'). (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37898) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 20, line 30) (in query: SELECT toDate32('2022-08-22 01:02:03.2b');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162d6c75 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162cbf14 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161def3c 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016202307 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000162018a0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.080842 [ 2095 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.2b' as Date32: syntax error at position 21 (parsed just '2022-08-22 01:02:03.2'): In scope SELECT toDate32('2022-08-22 01:02:03.2b'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162d6c75 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162cbf14 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161def3c 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016202307 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000162018a0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.092284 [ 2095 ] {adad221a-76a8-4dfd-b2f7-21be01eae2a0} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.a' as Date: syntax error at position 20 (parsed just '2022-08-22 01:02:03.'): In scope SELECT toDate('2022-08-22 01:02:03.a'). (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37898) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 21, line 32) (in query: SELECT toDate('2022-08-22 01:02:03.a');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c4115 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.093673 [ 2095 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.a' as Date: syntax error at position 20 (parsed just '2022-08-22 01:02:03.'): In scope SELECT toDate('2022-08-22 01:02:03.a'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162c4115 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162b7154 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161de5fc 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016200807 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ffda0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.107258 [ 2095 ] {d299a437-420c-41c7-872b-d3cedf62d6af} executeQuery: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.b' as Date32: syntax error at position 20 (parsed just '2022-08-22 01:02:03.'): In scope SELECT toDate32('2022-08-22 01:02:03.b'). (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37898) (comment: 02388_conversion_from_string_with_datetime64_to_date_and_date32.sql) (query 22, line 33) (in query: SELECT toDate32('2022-08-22 01:02:03.b');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162d6c75 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162cbf14 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161def3c 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016202307 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000162018a0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:56.108797 [ 2095 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '2022-08-22 01:02:03.b' as Date32: syntax error at position 20 (parsed just '2022-08-22 01:02:03.'): In scope SELECT toDate32('2022-08-22 01:02:03.b'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000162d6c75 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162cbf14 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161def3c 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016202307 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000162018a0 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:11:57.286250 [ 3097 ] {494c6e9a-1a9e-4d36-a3ac-cfa63b532a95} BackupsWorker: Failed to restore from backup Disk('backups', '03315_query_log_privileges_backup_restore_test_9h6bm6w5'): Code: 497. DB::Exception: u_03315_query_log_test_9h6bm6w5: Not enough privileges. To execute this query, it's necessary to have the grant INSERT, CREATE TABLE ON test_9h6bm6w5.d_03315_query_log. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36a23 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, String const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d34fb7 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d342ab 7. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 8. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 9. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 10. ./build_docker/./src/Backups/RestorerFromBackup.cpp:730: DB::RestorerFromBackup::checkAccessForObjectsFoundInBackup() const @ 0x0000000016f93b47 11. ./build_docker/./src/Backups/RestorerFromBackup.cpp:160: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x0000000016f8ed40 12. ./build_docker/./src/Backups/BackupsWorker.cpp:948: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x0000000016ed202b 13. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x0000000016ee1343 14. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000016ed7fcd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001686e1a3 16. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000001686e495 17. ./src/Common/threadPoolCallbackRunner.h:52: void std::__function::__policy_invoker::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001686e3cd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000001686d565 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000001686d245 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016ecb163 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x0000000016ecaab0 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x0000000018eb3a22 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:11:57.287991 [ 2054 ] {494c6e9a-1a9e-4d36-a3ac-cfa63b532a95} executeQuery: Code: 497. DB::Exception: u_03315_query_log_test_9h6bm6w5: Not enough privileges. To execute this query, it's necessary to have the grant INSERT, CREATE TABLE ON test_9h6bm6w5.d_03315_query_log. (ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58292) (comment: 03315_query_log_privileges_backup_restore.sh) (query 1, line 1) (in query: restore all from Disk('backups', '03315_query_log_privileges_backup_restore_test_9h6bm6w5')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36a23 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, String const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d34fb7 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d342ab 7. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 8. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 9. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 10. ./build_docker/./src/Backups/RestorerFromBackup.cpp:730: DB::RestorerFromBackup::checkAccessForObjectsFoundInBackup() const @ 0x0000000016f93b47 11. ./build_docker/./src/Backups/RestorerFromBackup.cpp:160: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x0000000016f8ed40 12. ./build_docker/./src/Backups/BackupsWorker.cpp:948: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x0000000016ed202b 13. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x0000000016ee1343 14. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000016ed7fcd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001686e1a3 16. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000001686e495 17. ./src/Common/threadPoolCallbackRunner.h:52: void std::__function::__policy_invoker::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001686e3cd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:11:57.290304 [ 2054 ] {} TCPHandler: Code: 497. DB::Exception: u_03315_query_log_test_9h6bm6w5: Not enough privileges. To execute this query, it's necessary to have the grant INSERT, CREATE TABLE ON test_9h6bm6w5.d_03315_query_log. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36a23 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, String const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d34fb7 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d342ab 7. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 8. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 9. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 10. ./build_docker/./src/Backups/RestorerFromBackup.cpp:730: DB::RestorerFromBackup::checkAccessForObjectsFoundInBackup() const @ 0x0000000016f93b47 11. ./build_docker/./src/Backups/RestorerFromBackup.cpp:160: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x0000000016f8ed40 12. ./build_docker/./src/Backups/BackupsWorker.cpp:948: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x0000000016ed202b 13. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x0000000016ee1343 14. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000016ed7fcd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001686e1a3 16. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000001686e495 17. ./src/Common/threadPoolCallbackRunner.h:52: void std::__function::__policy_invoker::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001686e3cd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000001686d565 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000001686d245 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016ecb163 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x0000000016ecaab0 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x0000000018eb3a22 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:11:59.439381 [ 2053 ] {cd560fba-9615-480e-bece-15f41ec4b15b} executeQuery: Code: 36. DB::Exception: It's not allowed to specify explicit zookeeper_path and replica_name for ReplicatedMergeTree arguments in Replicated database. If you really want to specify them explicitly, enable setting database_replicated_allow_replicated_engine_arguments. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02514_database_replicated_no_arguments_for_rmt.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_pinvvg84_db.tab_rmt_fail UUID 'b7f9a4a5-0708-498e-90d3-beca2357612d' (`x` UInt32) ENGINE = ReplicatedMergeTree('/clickhouse/tables/02514_database_replicated_no_arguments_for_rmt_test_pinvvg84/root/{shard}', '{replica}') ORDER BY x SETTINGS index_granularity = 3540, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 393777588, compact_parts_max_bytes_to_buffer = 296521997, compact_parts_max_granules_to_buffer = 19, compact_parts_merge_max_bytes_to_prefetch_part = 11315315, merge_max_block_size = 2818, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 5107990561, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 211367185, index_granularity_bytes = 7034514, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 56, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 70901, primary_key_compress_block_size = 22737, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:268: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::lts_20250127::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&) @ 0x000000001b7a3714 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:530: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7a5e8b 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000017702076 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000176cf65f 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5cd7 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:11:59.452182 [ 2053 ] {cd560fba-9615-480e-bece-15f41ec4b15b} executeQuery: Code: 36. DB::Exception: It's not allowed to specify explicit zookeeper_path and replica_name for ReplicatedMergeTree arguments in Replicated database. If you really want to specify them explicitly, enable setting database_replicated_allow_replicated_engine_arguments. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58408) (comment: 02514_database_replicated_no_arguments_for_rmt.sh) (query 1, line 1) (in query: CREATE TABLE test_pinvvg84_db.tab_rmt_fail (`x` UInt32) ENGINE = ReplicatedMergeTree('/clickhouse/tables/02514_database_replicated_no_arguments_for_rmt_test_pinvvg84/root/{shard}', '{replica}') ORDER BY x SETTINGS index_granularity = 3540, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 393777588, compact_parts_max_bytes_to_buffer = 296521997, compact_parts_max_granules_to_buffer = 19, compact_parts_merge_max_bytes_to_prefetch_part = 11315315, merge_max_block_size = 2818, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 5107990561, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 211367185, index_granularity_bytes = 7034514, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 56, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 70901, primary_key_compress_block_size = 22737, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:268: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::lts_20250127::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&) @ 0x000000001b7a3714 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:530: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7a5e8b 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000017702076 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000176cf65f 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5cd7 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:11:59.454530 [ 2053 ] {} TCPHandler: Code: 36. DB::Exception: It's not allowed to specify explicit zookeeper_path and replica_name for ReplicatedMergeTree arguments in Replicated database. If you really want to specify them explicitly, enable setting database_replicated_allow_replicated_engine_arguments. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:268: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::lts_20250127::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&) @ 0x000000001b7a3714 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:530: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7a5e8b 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182ae867 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000182abfb3 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000017702076 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000176cf65f 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5cd7 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:11:59.784562 [ 1855 ] {57ce091e-4af4-471d-b27f-6e0d5ccb7c9f} auto DB::FileCache::initialize()::(anonymous class)::operator()() const: Code: 36. DB::Exception: The total capacity of the disk containing cache path /var/lib/clickhouse/filesystem_caches/03324_cache_disk_validation_max_size_test_jpafv53x_1 is less than the specified max_size 109951162777600 bytes. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/Cache/FileCache.cpp:220: void std::__call_once_proxy[abi:ne190107]>(void*) @ 0x0000000018edb17c 5. ./build_docker/./contrib/llvm-project/libcxx/src/call_once.cpp:57: std::__call_once(unsigned long volatile&, void*, void (*)(void*)) @ 0x0000000025b9a701 6. ./contrib/llvm-project/libcxx/include/__mutex/once_flag.h:131: DB::FileCache::initialize() @ 0x0000000018ec32bc 7. ./build_docker/./src/Disks/ObjectStorages/Cached/CachedObjectStorage.cpp:34: DB::CachedObjectStorage::CachedObjectStorage(std::shared_ptr, std::shared_ptr, DB::FileCacheSettings const&, String const&) @ 0x0000000017903266 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DiskObjectStorage::wrapWithCache(std::shared_ptr, DB::FileCacheSettings const&, String const&) @ 0x00000000179027c6 9. ./build_docker/./src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:120: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x00000000178b5bd0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001785b03f 11. ./build_docker/./src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:ne190107], String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x000000001b5f5b1b 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000181c2829 13. ./build_docker/./src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x000000001b5f4ae1 14. ./build_docker/./src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x000000001b5f62dc 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001b5f602d 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001b5f5639 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x000000001b5969d7 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x000000001b59adb0 19. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7a8b67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:11:59.794346 [ 1855 ] {57ce091e-4af4-471d-b27f-6e0d5ccb7c9f} executeQuery: Code: 36. DB::Exception: The total capacity of the disk containing cache path /var/lib/clickhouse/filesystem_caches/03324_cache_disk_validation_max_size_test_jpafv53x_1 is less than the specified max_size 109951162777600 bytes: While processing disk(name = '03324_cache_disk_validation_max_size_test_jpafv53x_1', type = cache, max_size = '100Ti', path = '03324_cache_disk_validation_max_size_test_jpafv53x_1', disk = s3_disk). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58422) (comment: 03324_cache_disk_validation_max_size.sh) (query 2, line 3) (in query: CREATE TABLE test (`a` Int32, `b` String) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(name = '03324_cache_disk_validation_max_size_test_jpafv53x_1', type = cache, max_size = '100Ti', path = '03324_cache_disk_validation_max_size_test_jpafv53x_1', disk = s3_disk), index_granularity = 16478, min_bytes_for_wide_part = 466627408, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 9, min_bytes_for_full_part_storage = 164807645, compact_parts_max_bytes_to_buffer = 491194481, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 2480030, merge_max_block_size = 8616, old_parts_lifetime = 208., prefer_fetch_merged_part_size_threshold = 7100160649, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3346235696, index_granularity_bytes = 24279800, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 86, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 94696, primary_key_compress_block_size = 75224, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/Cache/FileCache.cpp:220: void std::__call_once_proxy[abi:ne190107]>(void*) @ 0x0000000018edb17c 5. ./build_docker/./contrib/llvm-project/libcxx/src/call_once.cpp:57: std::__call_once(unsigned long volatile&, void*, void (*)(void*)) @ 0x0000000025b9a701 6. ./contrib/llvm-project/libcxx/include/__mutex/once_flag.h:131: DB::FileCache::initialize() @ 0x0000000018ec32bc 7. ./build_docker/./src/Disks/ObjectStorages/Cached/CachedObjectStorage.cpp:34: DB::CachedObjectStorage::CachedObjectStorage(std::shared_ptr, std::shared_ptr, DB::FileCacheSettings const&, String const&) @ 0x0000000017903266 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DiskObjectStorage::wrapWithCache(std::shared_ptr, DB::FileCacheSettings const&, String const&) @ 0x00000000179027c6 9. ./build_docker/./src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:120: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x00000000178b5bd0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001785b03f 11. ./build_docker/./src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:ne190107], String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x000000001b5f5b1b 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000181c2829 13. ./build_docker/./src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x000000001b5f4ae1 14. ./build_docker/./src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x000000001b5f62dc 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001b5f602d 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001b5f5639 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x000000001b5969d7 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x000000001b59adb0 19. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7a8b67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:11:59.797329 [ 1855 ] {} TCPHandler: Code: 36. DB::Exception: The total capacity of the disk containing cache path /var/lib/clickhouse/filesystem_caches/03324_cache_disk_validation_max_size_test_jpafv53x_1 is less than the specified max_size 109951162777600 bytes: While processing disk(name = '03324_cache_disk_validation_max_size_test_jpafv53x_1', type = cache, max_size = '100Ti', path = '03324_cache_disk_validation_max_size_test_jpafv53x_1', disk = s3_disk). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/Cache/FileCache.cpp:220: void std::__call_once_proxy[abi:ne190107]>(void*) @ 0x0000000018edb17c 5. ./build_docker/./contrib/llvm-project/libcxx/src/call_once.cpp:57: std::__call_once(unsigned long volatile&, void*, void (*)(void*)) @ 0x0000000025b9a701 6. ./contrib/llvm-project/libcxx/include/__mutex/once_flag.h:131: DB::FileCache::initialize() @ 0x0000000018ec32bc 7. ./build_docker/./src/Disks/ObjectStorages/Cached/CachedObjectStorage.cpp:34: DB::CachedObjectStorage::CachedObjectStorage(std::shared_ptr, std::shared_ptr, DB::FileCacheSettings const&, String const&) @ 0x0000000017903266 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DiskObjectStorage::wrapWithCache(std::shared_ptr, DB::FileCacheSettings const&, String const&) @ 0x00000000179027c6 9. ./build_docker/./src/Disks/ObjectStorages/Cached/registerDiskCache.cpp:120: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x00000000178b5bd0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001785b03f 11. ./build_docker/./src/Disks/DiskFromAST.cpp:57: std::shared_ptr std::__function::__policy_invoker (std::map, std::less, std::allocator>>> const&)>::__call_impl[abi:ne190107], String const&, std::shared_ptr, bool)::$_0, std::shared_ptr (std::map, std::less, std::allocator>>> const&)>>(std::__function::__policy_storage const*, std::map, std::less, std::allocator>>> const&) @ 0x000000001b5f5b1b 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000181c2829 13. ./build_docker/./src/Disks/DiskFromAST.cpp:56: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x000000001b5f4ae1 14. ./build_docker/./src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x000000001b5f62dc 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001b5f602d 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001b5f5639 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x000000001b5969d7 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x000000001b59adb0 19. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7a8b67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:12:06.418547 [ 2064 ] {2751e063-e9a5-4919-9bec-9448f4271a74} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58676) (comment: 00595_insert_into_view.sh) (query 1, line 1) (in query: INSERT INTO test_view_00595 VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/IStorage.cpp:162: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001aa22231 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:630: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001c1a4cf7 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000189146b7 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000018916a9a 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891a3f0 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000001891c6d8 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:06.421485 [ 2064 ] {} TCPHandler: Code: 48. DB::Exception: Method write is not supported by storage View. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/IStorage.cpp:162: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001aa22231 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:630: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001c1a4cf7 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000189146b7 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000018916a9a 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891a3f0 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x000000001891c6d8 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:07.235902 [ 2070 ] {2990f90c-65f3-4eba-88e8-76a019b9a57c} executeQuery: Code: 36. DB::Exception: Identifier 'test_foo_#' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36456) (comment: 03234_enable_secure_identifiers.sql) (query 2, line 2) (in query: CREATE TABLE `test_foo_#` ( `date` Date, `town` LowCardinality(String), ) ENGINE = MergeTree PRIMARY KEY (town, date) PARTITION BY toYear(date) COMMENT 'test' -- to end ENGINE definition, so SETTINGS will be in the query level SETTINGS enforce_strict_identifier_format=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000001cfa37ab 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000001cfa3331 6. ./build_docker/./src/Parsers/ASTIdentifier.cpp:0: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const::$_0::operator()(String const&) const @ 0x000000001ceee379 7. ./build_docker/./src/Parsers/ASTIdentifier.cpp:149: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceedec3 8. ./build_docker/./src/Parsers/ASTWithAlias.cpp:35: DB::ASTWithAlias::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001cf4ea69 9. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb834d 10. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001cf10284 11. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ab93fcc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e12b97 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:12:07.238079 [ 2070 ] {} TCPHandler: Code: 36. DB::Exception: Identifier 'test_foo_#' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000001cfa37ab 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000001cfa3331 6. ./build_docker/./src/Parsers/ASTIdentifier.cpp:0: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const::$_0::operator()(String const&) const @ 0x000000001ceee379 7. ./build_docker/./src/Parsers/ASTIdentifier.cpp:149: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceedec3 8. ./build_docker/./src/Parsers/ASTWithAlias.cpp:35: DB::ASTWithAlias::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001cf4ea69 9. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb834d 10. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001cf10284 11. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ab93fcc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e12b97 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:12:07.386471 [ 2070 ] {0d20d6c7-6872-4dc0-9f23-0349783ab46c} executeQuery: Code: 36. DB::Exception: Identifier 'insecure_#' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36456) (comment: 03234_enable_secure_identifiers.sql) (query 5, line 16) (in query: CREATE TABLE test_foo ( `insecure_#` Int8, `date` Date, `town` LowCardinality(String), ) ENGINE = MergeTree PRIMARY KEY (town, date) PARTITION BY toYear(date) COMMENT 'test' -- to end ENGINE definition, so SETTINGS will be in the query level SETTINGS enforce_strict_identifier_format=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000001cfa37ab 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000001cfa3331 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ce978be 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb3a4f 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ced821e 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb5b70 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb9e85 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001cf10284 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ab93fcc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e12b97 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:12:07.387504 [ 2070 ] {} TCPHandler: Code: 36. DB::Exception: Identifier 'insecure_#' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000001cfa37ab 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000001cfa3331 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ce978be 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb3a4f 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ced821e 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb5b70 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb9e85 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001cf10284 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ab93fcc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e12b97 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:12:07.406943 [ 2070 ] {ebccb06b-4c68-4b20-baef-705874a61a3a} executeQuery: Code: 36. DB::Exception: Identifier 'insecure_'' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36456) (comment: 03234_enable_secure_identifiers.sql) (query 7, line 29) (in query: CREATE TABLE test_foo ( `insecure_'` Int8, `date` Date, `town` LowCardinality(String), ) ENGINE = MergeTree PRIMARY KEY (town, date) PARTITION BY toYear(date) COMMENT 'test' -- to end ENGINE definition, so SETTINGS will be in the query level SETTINGS enforce_strict_identifier_format=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000001cfa37ab 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000001cfa3331 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ce978be 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb3a4f 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ced821e 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb5b70 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb9e85 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001cf10284 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ab93fcc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e12b97 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:12:07.410633 [ 2070 ] {} TCPHandler: Code: 36. DB::Exception: Identifier 'insecure_'' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000001cfa37ab 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000001cfa3331 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ce978be 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb3a4f 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ced821e 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb5b70 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb9e85 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001cf10284 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ab93fcc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e12b97 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:12:07.437514 [ 2070 ] {b5bc7de5-6662-449b-9805-3bac813817a4} executeQuery: Code: 36. DB::Exception: Identifier 'insecure_"' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36456) (comment: 03234_enable_secure_identifiers.sql) (query 9, line 42) (in query: CREATE TABLE test_foo ( `insecure_"` Int8, `date` Date, `town` LowCardinality(String), ) ENGINE = MergeTree PRIMARY KEY (town, date) PARTITION BY toYear(date) COMMENT 'test' -- to end ENGINE definition, so SETTINGS will be in the query level SETTINGS enforce_strict_identifier_format=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000001cfa37ab 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000001cfa3331 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ce978be 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb3a4f 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ced821e 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb5b70 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb9e85 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001cf10284 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ab93fcc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e12b97 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:12:07.439641 [ 2070 ] {} TCPHandler: Code: 36. DB::Exception: Identifier 'insecure_"' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000001cfa37ab 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000001cfa3331 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ce978be 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb3a4f 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ced821e 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb5b70 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceb9e85 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001cf10284 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ab93fcc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e12b97 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:12:07.872236 [ 2070 ] {c35896f3-83f3-4edf-aacf-6303d254f285} executeQuery: Code: 36. DB::Exception: Identifier 'test_foo$' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36456) (comment: 03234_enable_secure_identifiers.sql) (query 20, line 106) (in query: -- SHOW CREATE .. query contains an insecure identifier (`test_foo$`) with `enforce_strict_identifier_format` SHOW CREATE TABLE `test_foo$` SETTINGS enforce_strict_identifier_format=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000001cfa37ab 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000001cfa3331 6. ./build_docker/./src/Parsers/ASTIdentifier.cpp:0: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const::$_0::operator()(String const&) const @ 0x000000001ceee379 7. ./build_docker/./src/Parsers/ASTIdentifier.cpp:149: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceedec3 8. ./build_docker/./src/Parsers/ASTWithAlias.cpp:35: DB::ASTWithAlias::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001cf4ea69 9. ./src/Parsers/IAST.h:266: DB::ASTQueryWithTableAndOutputImpl::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001d016503 10. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001cf10284 11. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ab93fcc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e12b97 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:12:07.873510 [ 2070 ] {} TCPHandler: Code: 36. DB::Exception: Identifier 'test_foo$' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000001cfa37ab 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000001cfa3331 6. ./build_docker/./src/Parsers/ASTIdentifier.cpp:0: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const::$_0::operator()(String const&) const @ 0x000000001ceee379 7. ./build_docker/./src/Parsers/ASTIdentifier.cpp:149: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001ceedec3 8. ./build_docker/./src/Parsers/ASTWithAlias.cpp:35: DB::ASTWithAlias::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001cf4ea69 9. ./src/Parsers/IAST.h:266: DB::ASTQueryWithTableAndOutputImpl::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001d016503 10. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000001cf10284 11. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ab93fcc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e12b97 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:12:09.304731 [ 1865 ] {ed275641-47dd-4e93-9d2d-308953b7f14f} executeQuery: Code: 43. DB::Exception: Illegal type Date of argument of function toTimezone. Should be DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTimeZone(N, 'UTC') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 2, line 2) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toTimeZone(N, 'UTC') as r FORMAT CSV;) 2025.07.28 06:12:09.306968 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of argument of function toTimezone. Should be DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTimeZone(N, 'UTC') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:09.389138 [ 1851 ] {d78a4e9d-7dc9-40a2-be35-f6dbeec11097} executeQuery: Code: 344. DB::Exception: FINAL modifier is not supported with parallel replicas. (SUPPORT_IS_DISABLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36514) (comment: 03222_parallel_replicas_final_in_subquery.sql) (query 7, line 20) (in query: SELECT * FROM (SELECT * FROM test_00808 FINAL) WHERE id = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/Planner.cpp:1517: DB::Planner::buildPlanForQueryNode() @ 0x000000001898c742 5. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1202: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189a66c1 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:12:09.390551 [ 1851 ] {} TCPHandler: Code: 344. DB::Exception: FINAL modifier is not supported with parallel replicas. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/Planner.cpp:1517: DB::Planner::buildPlanForQueryNode() @ 0x000000001898c742 5. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1202: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189a66c1 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:12:09.449184 [ 1855 ] {9c8c1b62-3b3c-4eb8-8b36-e3dd45e0f152} executeQuery: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36536) (comment: 01422_map_skip_null.sql) (query 1, line 1) (in query: select minMap(arrayJoin([([1], [null]), ([1], [null])]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:453: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013be2ef8 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:258: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x0000000016471659 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:12:09.451061 [ 1855 ] {} TCPHandler: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:453: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013be2ef8 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:258: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x0000000016471659 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:12:09.462738 [ 1855 ] {6ddf6d4c-3209-4ae9-b3c7-61e21e77e42c} executeQuery: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36536) (comment: 01422_map_skip_null.sql) (query 2, line 2) (in query: select maxMap(arrayJoin([([1], [null]), ([1], [null])]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:453: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013be2ef8 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:258: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x0000000016471659 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:12:09.463824 [ 1855 ] {} TCPHandler: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:453: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013be2ef8 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:258: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x0000000016471659 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:12:09.476808 [ 1855 ] {167b6091-3b4f-4b84-a2f8-e72c83bb1c27} executeQuery: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36536) (comment: 01422_map_skip_null.sql) (query 3, line 3) (in query: select sumMap(arrayJoin([([1], [null]), ([1], [null])]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:453: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013be2ef8 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:258: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x0000000016471659 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:12:09.478946 [ 1855 ] {} TCPHandler: Code: 43. DB::Exception: Aggregation 'nothingNullMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:453: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013be2ef8 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:258: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x0000000016471659 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:12:09.626153 [ 1855 ] {2cd3c31c-7b1e-46a9-8136-f43114b81236} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36536) (comment: 01422_map_skip_null.sql) (query 4, line 4) (in query: select sumMapWithOverflow(arrayJoin([([1], [null]), ([1], [null])]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000012c197be 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:12:09.627445 [ 1855 ] {} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000012c197be 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:12:10.723217 [ 1865 ] {5ad62b8f-758d-4ace-9057-4f023ecfa699} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 37, line 37) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toHour(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:10.724039 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:10.868126 [ 1865 ] {b84eb526-71b1-4d2a-85df-18611b6b1de0} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 42, line 42) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toMinute(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:10.868860 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:11.011473 [ 1865 ] {275df62a-cf4c-46c5-903b-02da2001a57f} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toSecond: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toSecond(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 47, line 47) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toSecond(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:11.014226 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toSecond: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toSecond(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:11.327860 [ 1865 ] {32f039b2-00aa-4b1d-89ac-c1ae5ce70726} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 57, line 57) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfYear(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:11.329484 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:11.499674 [ 1865 ] {dbaf2b61-1f2f-453d-b245-5bf767b167ed} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfISOYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfISOYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 62, line 62) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfISOYear(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:11.500626 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfISOYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfISOYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:11.703644 [ 1865 ] {83f30488-c0a9-4bb9-8ed9-1f07570cdca3} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfQuarter is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfQuarter(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 67, line 67) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfQuarter(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:11.705210 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfQuarter is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfQuarter(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:11.841982 [ 1865 ] {7c9fa464-0d5a-4299-9525-fbb7c96b1cb5} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfMonth is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMonth(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 72, line 72) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfMonth(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:11.842773 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfMonth is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMonth(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:11.979967 [ 1865 ] {de963149-c58f-4789-b76d-4a42df9ffc8e} executeQuery: Code: 43. DB::Exception: The timezone argument of function toMonday is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMonday(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 77, line 77) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toMonday(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:11.980754 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toMonday is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMonday(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:12.134541 [ 1865 ] {cb74a47a-11f1-4843-81ee-77940a82c43a} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 82, line 82) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:12.135318 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:12.161222 [ 1865 ] {671b4fbb-d42b-4561-8d0f-561cdf175550} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 83, line 83) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:12.162096 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:12.195546 [ 1865 ] {d5a8d826-3ddd-4658-a20b-22f8c9dcdb69} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 84, line 84) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:12.210591 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:12.460655 [ 1865 ] {b003d806-00b6-4789-a5ba-e0cdaf79bacc} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 92, line 92) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfHour(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:12.461434 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:12.599849 [ 1865 ] {39501a44-8839-44ea-8bcd-7724fc0cf67d} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 97, line 97) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfMinute(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:12.602614 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:12.754843 [ 1865 ] {1e3baf10-a10d-49ca-8724-8d4a6e44b42a} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFiveMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFiveMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 102, line 102) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfFiveMinutes(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:12.755572 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFiveMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFiveMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:12.884841 [ 1865 ] {5ff9dbcf-d80b-4f88-a6d2-a4f66bf0ebb0} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfTenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfTenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 107, line 107) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfTenMinutes(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:12.885574 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfTenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfTenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:13.019232 [ 1865 ] {fec2b3d5-1e4f-4e86-8963-fd63c1988167} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFifteenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFifteenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 112, line 112) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfFifteenMinutes(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:13.022587 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFifteenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFifteenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:13.271854 [ 1865 ] {7be25d09-3c52-4f78-9b4b-a879df0758c1} executeQuery: Code: 43. DB::Exception: A timezone argument of function toStartOfInterval with interval type Year is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalYear(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 117, line 117) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfInterval(N, INTERVAL 1 year, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:13.272806 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: A timezone argument of function toStartOfInterval with interval type Year is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalYear(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:13.430322 [ 1865 ] {bf120f90-f5c0-4106-b92c-5221334797a9} executeQuery: Code: 43. DB::Exception: A timezone argument of function toStartOfInterval with interval type Month is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMonth(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 122, line 122) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfInterval(N, INTERVAL 1 month, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:13.432796 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: A timezone argument of function toStartOfInterval with interval type Month is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMonth(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:13.769051 [ 1865 ] {2d0ad7fc-58b4-48ef-be26-b27e0f917f1a} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMinute(15), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 132, line 132) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfInterval(N, INTERVAL 15 minute, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:13.770046 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMinute(15), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:13.931437 [ 1865 ] {dd19abad-3562-4df4-a2b1-07f9d9db6801} executeQuery: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'year' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('year', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 137, line 137) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), date_trunc('year', N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:13.935059 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'year' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('year', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:14.125602 [ 1865 ] {0b5a10e4-ec55-42c5-b80b-0e0807f27990} executeQuery: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'month' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('month', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 142, line 142) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), date_trunc('month', N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:14.130583 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'month' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('month', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:14.526927 [ 1865 ] {86e036dd-e075-4139-9154-0e9134674f0b} executeQuery: Code: 43. DB::Exception: Illegal type Date of argument for function dateTrunc: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('minute', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 152, line 152) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), date_trunc('minute', N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:14.528421 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of argument for function dateTrunc: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('minute', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:14.681307 [ 1865 ] {a8fdb82f-5d6d-41dd-97ae-b755c1315684} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTime(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 157, line 157) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toTime(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:14.682664 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTime(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:16.467317 [ 1865 ] {605900d8-3c28-4c0b-a71e-31e384fce375} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 212, line 212) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:16.468273 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:16.500637 [ 1865 ] {e083e733-2155-4b1c-85cf-dce2bd5d5400} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 213, line 213) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:16.501805 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:16.531466 [ 1865 ] {d3f99385-658f-486f-bc59-4a816e52d129} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 214, line 214) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:16.532640 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:16.619543 [ 1865 ] {55fbf07c-bb2c-4611-9c63-b35ac3f53f7a} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 217, line 217) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:16.622529 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:16.648138 [ 1865 ] {7885008b-80b2-4091-924d-c2e45674304a} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 218, line 218) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:16.649730 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:16.678624 [ 1865 ] {3abaf286-1539-4b8d-b301-167e7bf58506} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 219, line 219) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:16.686186 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:16.772356 [ 1865 ] {009c1cb6-270e-4111-900e-42e0604e2e8b} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function timeSlot: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), timeSlot(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 222, line 222) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), timeSlot(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:16.773712 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function timeSlot: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), timeSlot(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:17.360844 [ 1865 ] {236d0b9b-69ea-4c1c-b99d-03bfc61ef1f7} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 242, line 242) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addYears(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:17.361879 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:17.507575 [ 1865 ] {9f459bbf-e8e0-473c-8052-1319b02f8112} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 247, line 247) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addMonths(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:17.508596 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:17.568058 [ 6818 ] {b8c7e77a-c692-4816-b429-20882a501d6d} executeQuery: Code: 35. DB::Exception: At least one UInt argument is required for function hilbertEncode: In scope SELECT hilbertEncode(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36630) (comment: 03131_hilbert_coding.sql) (query 16, line 48) (in query: select hilbertEncode();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionSpaceFillingCurveEncode::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b99c87c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:17.570384 [ 6818 ] {} TCPHandler: Code: 35. DB::Exception: At least one UInt argument is required for function hilbertEncode: In scope SELECT hilbertEncode(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionSpaceFillingCurveEncode::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b99c87c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:17.627529 [ 1865 ] {4079ccee-bbc0-4149-bccb-298f0d0119e9} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 252, line 252) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addWeeks(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:17.628557 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:17.701341 [ 6818 ] {308413b6-0491-4575-81b0-8ad2774a7d88} executeQuery: Code: 34. DB::Exception: Illegal number of UInt arguments of function hilbertEncode: should be not more than 2 dimensions: In scope SELECT hilbertEncode(1, 2, 3). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36630) (comment: 03131_hilbert_coding.sql) (query 17, line 49) (in query: select hilbertEncode(1, 2, 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionHilbertEncode::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b99c1f1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:12:17.702806 [ 6818 ] {} TCPHandler: Code: 34. DB::Exception: Illegal number of UInt arguments of function hilbertEncode: should be not more than 2 dimensions: In scope SELECT hilbertEncode(1, 2, 3). (TOO_MANY_ARGUMENTS_FOR_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionHilbertEncode::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b99c1f1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:12:17.709737 [ 6818 ] {b7f85c63-5048-4263-bc9f-7df6d3e5474e} executeQuery: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 0, should be 2: In scope SELECT hilbertDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36630) (comment: 03131_hilbert_coding.sql) (query 18, line 50) (in query: select hilbertDecode();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:12:17.710710 [ 6818 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 0, should be 2: In scope SELECT hilbertDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:12:17.770370 [ 1865 ] {edcb4a68-741e-4077-933a-3fcdd0b997bd} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 257, line 257) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addDays(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:17.771379 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:18.016914 [ 1865 ] {689131d8-5f8f-48f7-8404-4b6777b6fe34} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 262, line 262) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addHours(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:18.018148 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:18.063072 [ 6818 ] {4168a964-d087-4615-88aa-cc44c7e10025} executeQuery: Code: 43. DB::Exception: Illegal type String of argument for function hilbertEncode, should be a native UInt: In scope SELECT hilbertEncode('text'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36630) (comment: 03131_hilbert_coding.sql) (query 19, line 51) (in query: select hilbertEncode('text');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionSpaceFillingCurveEncode::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b99c707 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:18.067194 [ 6818 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument for function hilbertEncode, should be a native UInt: In scope SELECT hilbertEncode('text'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionSpaceFillingCurveEncode::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b99c707 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:18.149956 [ 1865 ] {74b6432d-35a4-4e7d-94a9-039e279a4718} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 267, line 267) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addMinutes(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:18.151281 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:18.263163 [ 6818 ] {9490703a-7a5b-44a4-9e6e-81e9d5192301} executeQuery: Code: 44. DB::Exception: Illegal column type String for function hilbertDecode, should be a native UInt: In scope SELECT hilbertDecode('text', 'text'). (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36630) (comment: 03131_hilbert_coding.sql) (query 20, line 52) (in query: select hilbertDecode('text', 'text');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. _ZNK2DB31FunctionSpaceFillingCurveDecodeILDu2ELDu0ELDu32EE17getReturnTypeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS2_9allocatorIS4_EEEE @ 0x000000000b999ba9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:18.264622 [ 6818 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column type String for function hilbertDecode, should be a native UInt: In scope SELECT hilbertDecode('text', 'text'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. _ZNK2DB31FunctionSpaceFillingCurveDecodeILDu2ELDu0ELDu32EE17getReturnTypeImplERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS2_9allocatorIS4_EEEE @ 0x000000000b999ba9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:18.279708 [ 1865 ] {c307eb84-356e-4a31-b2e3-5869fe36a008} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 272, line 272) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addSeconds(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:18.280647 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:18.426625 [ 1865 ] {18da6514-8ba1-48d5-88e3-10a41b64b49d} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 277, line 277) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addQuarters(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:18.430466 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:18.440004 [ 6818 ] {f5d59f50-aca5-4ff9-8910-678d4a87d1d4} executeQuery: Code: 69. DB::Exception: Illegal argument Tuple(UInt8, UInt8) for function hilbertEncode, tuple size should be equal to number of UInt arguments: In scope SELECT hilbertEncode((1, 2), 3). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36630) (comment: 03131_hilbert_coding.sql) (query 21, line 53) (in query: select hilbertEncode((1, 2), 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionSpaceFillingCurveEncode::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b99c94c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:18.441322 [ 6818 ] {} TCPHandler: Code: 69. DB::Exception: Illegal argument Tuple(UInt8, UInt8) for function hilbertEncode, tuple size should be equal to number of UInt arguments: In scope SELECT hilbertEncode((1, 2), 3). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionSpaceFillingCurveEncode::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b99c94c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:18.564803 [ 1865 ] {aa9b4413-c44c-4d14-be37-c7653080fae9} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 282, line 282) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractYears(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:18.565622 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:18.699675 [ 1865 ] {f90c4a55-9ddf-4a5e-aff6-669f6bc953c0} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 287, line 287) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractMonths(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:18.700507 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:18.833033 [ 1865 ] {530e82d3-936c-4ff0-a2ba-6c604b22068b} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 292, line 292) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractWeeks(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:18.833889 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:18.964182 [ 1865 ] {d665d2eb-9e25-408f-94da-908d24e83f98} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 297, line 297) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractDays(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:18.966579 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:19.119466 [ 1865 ] {f37d2f87-046d-40c4-ae4a-1a958b142478} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 302, line 302) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractHours(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:19.120797 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:19.273688 [ 1865 ] {2e88ecbe-e3c0-47f3-9b23-c7cb65a729b4} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 307, line 307) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractMinutes(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:19.274770 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:19.390961 [ 1865 ] {a229c939-7a1e-475e-8685-ee6d0648ed71} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 312, line 312) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractSeconds(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:19.394483 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:19.536235 [ 1865 ] {6c733aa5-4623-4e28-b68c-c8a588fc6015} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 317, line 317) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractQuarters(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.07.28 06:12:19.537411 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:21.198501 [ 1865 ] {5c450c49-f8ce-477d-8dca-e614460f34c3} executeQuery: Code: 43. DB::Exception: Illegal types Date and Date of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 367, line 367) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N + N as r FORMAT CSV;) 2025.07.28 06:12:21.199861 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Date and Date of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:21.226987 [ 1865 ] {e72fc803-cc3b-4d6f-8169-6c2b615e06e0} executeQuery: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and DateTime('Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 368, line 368) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), N + N as r FORMAT CSV;) 2025.07.28 06:12:21.234078 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and DateTime('Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:21.255888 [ 1865 ] {a97830ca-2bb2-4899-9add-1b8e52048223} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 369, line 369) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), N + N as r FORMAT CSV;) 2025.07.28 06:12:21.256888 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:21.317047 [ 2052 ] {e1c240db-c514-446a-8750-22a4ad5d7ebf} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayROCAUC([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 1, line 1) (in query: SELECT arrayROCAUC([], []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138995 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:21.321003 [ 2052 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayROCAUC([], []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138995 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:21.630124 [ 2052 ] {14a3f7eb-5b75-47da-a497-433af5f26f98} executeQuery: Code: 43. DB::Exception: Second argument (arr_labels) for function arrayROCAUC is of type Nothing, should be a number or Enum: In scope SELECT arrayROCAUC([1], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 3, line 3) (in query: SELECT arrayROCAUC([1], []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138a57 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:21.631743 [ 2052 ] {} TCPHandler: Code: 43. DB::Exception: Second argument (arr_labels) for function arrayROCAUC is of type Nothing, should be a number or Enum: In scope SELECT arrayROCAUC([1], []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138a57 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:21.652586 [ 2052 ] {43cfd2e5-5dec-48b2-9361-e43ffa33de6d} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayROCAUC([], [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 4, line 4) (in query: SELECT arrayROCAUC([], [1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138995 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:21.653775 [ 2052 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayROCAUC([], [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138995 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:21.852946 [ 2052 ] {711fdd1b-d4d5-422d-837d-c5d0e1a834bd} executeQuery: Code: 36. DB::Exception: First two arguments for function arrayROCAUC must be Arrays of equal sizes: In scope SELECT arrayROCAUC([1, 2], [3]). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 5, line 5) (in query: SELECT arrayROCAUC([1, 2], [3]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f137d79 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:21.854580 [ 2052 ] {} TCPHandler: Code: 36. DB::Exception: First two arguments for function arrayROCAUC must be Arrays of equal sizes: In scope SELECT arrayROCAUC([1, 2], [3]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f137d79 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:21.869765 [ 2052 ] {c8c35d8b-0224-492c-a5ae-72f56138cd19} executeQuery: Code: 36. DB::Exception: First two arguments for function arrayROCAUC must be Arrays of equal sizes: In scope SELECT arrayROCAUC([1], [2, 3]). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 6, line 6) (in query: SELECT arrayROCAUC([1], [2, 3]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f137d79 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:21.871216 [ 2052 ] {} TCPHandler: Code: 36. DB::Exception: First two arguments for function arrayROCAUC must be Arrays of equal sizes: In scope SELECT arrayROCAUC([1], [2, 3]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f137d79 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:22.100065 [ 2052 ] {ee8b2c1e-2719-4a3f-add6-7b0a58ab9e08} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayROCAUC([], [], true). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 15, line 15) (in query: SELECT arrayROCAUC([], [], true);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138995 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.101838 [ 2052 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayROCAUC([], [], true). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138995 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.146854 [ 2052 ] {0ddbe948-fb5b-419b-b694-6ad7418a0792} executeQuery: Code: 43. DB::Exception: Second argument (arr_labels) for function arrayROCAUC is of type Nothing, should be a number or Enum: In scope SELECT arrayROCAUC([1], [], true). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 17, line 17) (in query: SELECT arrayROCAUC([1], [], true);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138a57 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.153011 [ 2052 ] {} TCPHandler: Code: 43. DB::Exception: Second argument (arr_labels) for function arrayROCAUC is of type Nothing, should be a number or Enum: In scope SELECT arrayROCAUC([1], [], true). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138a57 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.165171 [ 2052 ] {b6e2a162-356a-4e85-ba19-f5fe650f7940} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayROCAUC([], [1], true). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 18, line 18) (in query: SELECT arrayROCAUC([], [1], true);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138995 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.170587 [ 2052 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayROCAUC([], [1], true). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138995 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.180453 [ 2052 ] {afbb52e8-e4a9-4e14-ac85-ee12409c2ffe} executeQuery: Code: 36. DB::Exception: First two arguments for function arrayROCAUC must be Arrays of equal sizes: In scope SELECT arrayROCAUC([1, 2], [3], true). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 19, line 19) (in query: SELECT arrayROCAUC([1, 2], [3], true);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f137d79 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:22.182063 [ 2052 ] {} TCPHandler: Code: 36. DB::Exception: First two arguments for function arrayROCAUC must be Arrays of equal sizes: In scope SELECT arrayROCAUC([1, 2], [3], true). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f137d79 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:22.196236 [ 2052 ] {3dd03aba-3297-4fc0-8dea-dd379bc17b23} executeQuery: Code: 36. DB::Exception: First two arguments for function arrayROCAUC must be Arrays of equal sizes: In scope SELECT arrayROCAUC([1], [2, 3], true). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 20, line 20) (in query: SELECT arrayROCAUC([1], [2, 3], true);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f137d79 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:22.197661 [ 2052 ] {} TCPHandler: Code: 36. DB::Exception: First two arguments for function arrayROCAUC must be Arrays of equal sizes: In scope SELECT arrayROCAUC([1], [2, 3], true). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f137d79 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:22.367955 [ 1865 ] {7a8705a6-276b-4afa-94fa-511d77384d8d} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 402, line 402) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N - DT as r FORMAT CSV;) 2025.07.28 06:12:22.369222 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:22.415605 [ 2052 ] {57152109-157b-45a7-9658-f161a849a600} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayROCAUC([], [], false). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 29, line 29) (in query: SELECT arrayROCAUC([], [], false);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138995 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.417507 [ 2052 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayROCAUC([], [], false). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138995 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.450596 [ 2052 ] {ae6ae585-0018-495f-8ece-0de4a03a3832} executeQuery: Code: 43. DB::Exception: Second argument (arr_labels) for function arrayROCAUC is of type Nothing, should be a number or Enum: In scope SELECT arrayROCAUC([1], [], false). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 31, line 31) (in query: SELECT arrayROCAUC([1], [], false);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138a57 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.452249 [ 2052 ] {} TCPHandler: Code: 43. DB::Exception: Second argument (arr_labels) for function arrayROCAUC is of type Nothing, should be a number or Enum: In scope SELECT arrayROCAUC([1], [], false). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138a57 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.472336 [ 2052 ] {d582fac7-4f26-4c81-bc2e-e2aafdb99b17} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayROCAUC([], [1], false). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 32, line 32) (in query: SELECT arrayROCAUC([], [1], false);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138995 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.474054 [ 2052 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nothing, should be a number: In scope SELECT arrayROCAUC([], [1], false). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138995 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.483922 [ 2052 ] {a7786018-e326-4e79-9877-6f99f01e4185} executeQuery: Code: 36. DB::Exception: First two arguments for function arrayROCAUC must be Arrays of equal sizes: In scope SELECT arrayROCAUC([1, 2], [3], false). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 33, line 33) (in query: SELECT arrayROCAUC([1, 2], [3], false);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f137d79 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:22.485591 [ 2052 ] {} TCPHandler: Code: 36. DB::Exception: First two arguments for function arrayROCAUC must be Arrays of equal sizes: In scope SELECT arrayROCAUC([1, 2], [3], false). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f137d79 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:22.497981 [ 2052 ] {2804654f-0d63-4138-bfd5-a455f7fb2a3e} executeQuery: Code: 36. DB::Exception: First two arguments for function arrayROCAUC must be Arrays of equal sizes: In scope SELECT arrayROCAUC([1], [2, 3], false). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 34, line 34) (in query: SELECT arrayROCAUC([1], [2, 3], false);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f137d79 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:22.500048 [ 2052 ] {} TCPHandler: Code: 36. DB::Exception: First two arguments for function arrayROCAUC must be Arrays of equal sizes: In scope SELECT arrayROCAUC([1], [2, 3], false). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f137d79 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:22.539972 [ 1865 ] {bcbb50b2-a20e-4a9a-8bd5-381b08cddf24} executeQuery: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 407, line 407) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), DT - N as r FORMAT CSV;) 2025.07.28 06:12:22.541382 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:22.730255 [ 1865 ] {cb625d56-1a6c-4986-a743-ba2971252ad3} executeQuery: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 413, line 413) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), N - D as r FORMAT CSV;) 2025.07.28 06:12:22.733419 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:22.756558 [ 1865 ] {b16c60e3-d2c7-4d6e-917f-e7c6d987090a} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 414, line 414) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), N - D as r FORMAT CSV;) 2025.07.28 06:12:22.760016 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:22.817891 [ 2052 ] {f771f159-bc38-4b5a-b186-a4f7c782f9c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 5, should be 2, 3 or 4: In scope SELECT arrayROCAUC([0, 1, 1], [0, 0, 1], false, [0, 0, 0], true). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 43, line 43) (in query: SELECT arrayROCAUC([0, 1, 1], [0, 0, 1], false, [0, 0, 0], true);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000000f13da2c 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f1388d3 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.819227 [ 2052 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 5, should be 2, 3 or 4: In scope SELECT arrayROCAUC([0, 1, 1], [0, 0, 1], false, [0, 0, 0], true). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000000f13da2c 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f1388d3 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.832442 [ 2052 ] {6203c700-56c7-4ae4-8604-ee8f842bb935} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 1, should be 2, 3 or 4: In scope SELECT arrayROCAUC([0, 1, 1]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 44, line 44) (in query: SELECT arrayROCAUC([0, 1, 1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000000f13da2c 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f1388d3 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.834918 [ 2052 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayROCAUC doesn't match: passed 1, should be 2, 3 or 4: In scope SELECT arrayROCAUC([0, 1, 1]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000000f13da2c 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f1388d3 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.873482 [ 1865 ] {07b6a5d9-1740-4322-af6e-91fecf01de23} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 418, line 418) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), D - N as r FORMAT CSV;) 2025.07.28 06:12:22.878520 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:22.897724 [ 1865 ] {d31efcab-120a-4c93-8ad7-7ab09e4154e7} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 419, line 419) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), D - N as r FORMAT CSV;) 2025.07.28 06:12:22.899172 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:22.909529 [ 1855 ] {7dcb04d7-60c1-4f22-ab4f-ee899be01e2a} executeQuery: Code: 207. DB::Exception: JOIN , ... ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1, test_table_join_2. (AMBIGUOUS_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47898) (comment: 02371_analyzer_join_cross.sql) (query 33, line 73) (in query: SELECT id FROM test_table_join_1, test_table_join_2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000017ac59cc 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:841: DB::IdentifierResolver::tryResolveIdentifierFromCrossJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f01376 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1378: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f015c2 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1438: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000017f0618c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9921d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:12:22.917120 [ 1855 ] {} TCPHandler: Code: 207. DB::Exception: JOIN , ... ambiguous identifier 'id'. In scope SELECT id FROM test_table_join_1, test_table_join_2. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000017ac59cc 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:841: DB::IdentifierResolver::tryResolveIdentifierFromCrossJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f01376 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1378: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f015c2 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1438: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000017f0618c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9921d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:12:22.925679 [ 1855 ] {79b1ee63-5e61-4a9c-a276-cea49d959539} executeQuery: Code: 207. DB::Exception: JOIN , ... ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1, test_table_join_2. (AMBIGUOUS_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47898) (comment: 02371_analyzer_join_cross.sql) (query 34, line 75) (in query: SELECT value FROM test_table_join_1, test_table_join_2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000017ac59cc 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:841: DB::IdentifierResolver::tryResolveIdentifierFromCrossJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f01376 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1378: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f015c2 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1438: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000017f0618c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9921d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:12:22.927793 [ 1855 ] {} TCPHandler: Code: 207. DB::Exception: JOIN , ... ambiguous identifier 'value'. In scope SELECT value FROM test_table_join_1, test_table_join_2. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000017ac59cc 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:841: DB::IdentifierResolver::tryResolveIdentifierFromCrossJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f01376 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1378: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f015c2 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1438: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000017f0618c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9921d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:12:22.970999 [ 2052 ] {9c0883b5-8ad8-473b-b7f1-332c95da018a} executeQuery: Code: 43. DB::Exception: Third argument (scale) for function arrayROCAUC must be of type const Bool: In scope SELECT arrayROCAUC([0, 1, 1], [0, 0, 1], 'false'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 45, line 45) (in query: SELECT arrayROCAUC([0, 1, 1], [0, 0, 1], 'false');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138afe 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.974532 [ 1865 ] {71f7bcfe-5942-4814-b00a-c40fa7e8cff5} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT64 AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 422, line 422) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N - DT64 as r FORMAT CSV;) 2025.07.28 06:12:22.974851 [ 2052 ] {} TCPHandler: Code: 43. DB::Exception: Third argument (scale) for function arrayROCAUC must be of type const Bool: In scope SELECT arrayROCAUC([0, 1, 1], [0, 0, 1], 'false'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138afe 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.975823 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT64 AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:22.988492 [ 2052 ] {1369ce90-daef-42a3-ad1b-c287ce094de4} executeQuery: Code: 43. DB::Exception: Third argument (scale) for function arrayROCAUC must be of type const Bool: In scope SELECT arrayROCAUC([0, 1, 1], [0, 0, 1], 4). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47882) (comment: 01202_arrayROCAUC_special.sql) (query 46, line 46) (in query: SELECT arrayROCAUC([0, 1, 1], [0, 0, 1], 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138afe 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:22.992845 [ 2052 ] {} TCPHandler: Code: 43. DB::Exception: Third argument (scale) for function arrayROCAUC must be of type const Bool: In scope SELECT arrayROCAUC([0, 1, 1], [0, 0, 1], 4). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f138afe 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:12:23.141240 [ 1865 ] {02450421-8b6a-4a45-8fed-a6103497d876} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT64 - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 427, line 427) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), DT64 - N as r FORMAT CSV;) 2025.07.28 06:12:23.142640 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT64 - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:26.214252 [ 1856 ] {8bc8dbe9-6931-46b5-a261-a399a499984b} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 21, line 27) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t AND A.t < B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349936 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:26.220176 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349936 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:26.225114 [ 2053 ] {70d7f9bb-fb5d-4c9c-a928-cac004fa92f8} executeQuery: Code: 183. DB::Exception: Unexpected lambda expression: While processing x -> toString(x) AS lambda_2. (UNEXPECTED_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47960) (comment: 03248_invalid_where.sql) (query 1, line 1) (in query: WITH x -> toString(x) AS lambda_1 SELECT arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, ['1', '2', '3']) WHERE lambda_2 SETTINGS enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:923: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000001835f633 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018358954 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001834bf4d 7. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001831d06c 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1357: DB::SelectQueryExpressionAnalyzer::appendWhere(DB::ExpressionActionsChain&, bool) @ 0x000000001832a64a 9. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2071: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000001833356f 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1180: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000018947b86 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:920: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x000000001893be6c 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:930: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000189350eb 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001892fec6 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000018a165ca 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018a14a56 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000018a1a06d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:12:26.229339 [ 2053 ] {} TCPHandler: Code: 183. DB::Exception: Unexpected lambda expression: While processing x -> toString(x) AS lambda_2. (UNEXPECTED_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:923: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000001835f633 5. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018358954 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001834bf4d 7. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001831d06c 8. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1357: DB::SelectQueryExpressionAnalyzer::appendWhere(DB::ExpressionActionsChain&, bool) @ 0x000000001832a64a 9. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2071: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000001833356f 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1180: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000018947b86 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:920: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x000000001893be6c 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:930: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000189350eb 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001892fec6 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000018a165ca 15. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018a14a56 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000018a1a06d 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:12:26.345161 [ 1856 ] {b870f508-e6bd-4a44-afdf-297f815dbb2e} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 22, line 28) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:26.350994 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:26.374799 [ 1856 ] {d0067d8f-54e5-405b-b7f7-78117186f94c} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 23, line 29) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:26.381784 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:26.469389 [ 2053 ] {3111dccc-07b9-4a17-a8b6-603407f24814} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `lambda_2` in scope WITH x -> toString(x) AS lambda_1 SELECT arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, ['1', '2', '3']) WHERE lambda_2 SETTINGS enable_analyzer = 1. Maybe you meant: ['lambda_2']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47960) (comment: 03248_invalid_where.sql) (query 2, line 2) (in query: WITH x -> toString(x) AS lambda_1 SELECT arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, ['1', '2', '3']) WHERE lambda_2 SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5630: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7f0b0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:12:26.471927 [ 2053 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `lambda_2` in scope WITH x -> toString(x) AS lambda_1 SELECT arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, ['1', '2', '3']) WHERE lambda_2 SETTINGS enable_analyzer = 1. Maybe you meant: ['lambda_2']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5630: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7f0b0 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:12:26.565400 [ 1856 ] {b16bf844-bc64-4b21-a544-49285fe66187} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 24, line 31) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349b32 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:26.572016 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349b32 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.192121 [ 1856 ] {d09a7aea-6ead-4b80-b195-5632182c95fd} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 40, line 55) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t AND A.t < B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349936 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.195073 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349936 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.212947 [ 1856 ] {9472de8c-0da7-455f-bc68-c23dda3f82ad} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 41, line 56) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.216642 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.238634 [ 1856 ] {3d0521c2-1d42-408f-98c7-e00113705016} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 42, line 57) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.242824 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.276722 [ 1856 ] {f23b6217-528e-4a9c-9264-3ae7ff29377b} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 43, line 59) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349b32 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.279604 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349b32 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.852392 [ 1856 ] {8a1c7780-175f-4882-bed1-1a4c018ec68c} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 59, line 83) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t AND A.t < B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349936 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.853651 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349936 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.873216 [ 1856 ] {7c66d16a-b6e4-4702-8f04-27e83e721c75} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 60, line 84) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.881287 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.901390 [ 1856 ] {788833d4-3e2f-4c05-bfac-2718149066f8} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 61, line 85) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.903311 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.936319 [ 1856 ] {53200748-5a63-42a3-b097-b08a654603fe} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 62, line 87) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349b32 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:27.939373 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349b32 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:28.492645 [ 1856 ] {554edcce-7fbc-4f0b-a6be-bb501b87736d} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 78, line 111) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t AND A.t < B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349936 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:28.496393 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349936 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:28.512446 [ 1856 ] {f63e0ac1-886f-4cfe-a43f-c2693411e6b4} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 79, line 112) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:28.516524 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:28.535838 [ 1856 ] {61006310-5f95-490e-8896-bbeb95808bed} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 80, line 113) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:28.537719 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349a8d 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:28.568601 [ 1856 ] {7e3d2b11-aad8-4c80-b5f6-d251585488b2} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47942) (comment: 00976_asof_join_on.gen.sql) (query 81, line 115) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349b32 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:28.571800 [ 1856 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349b32 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:12:32.909934 [ 1865 ] {9d0360b4-1558-415c-83dd-fcc99be9f7ac} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 697, line 697) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) - N as r FORMAT CSV;) 2025.07.28 06:12:32.914760 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:32.938194 [ 1865 ] {84890b96-7a7d-40e1-ae75-711da1dd6016} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 698, line 698) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt8(1) - N as r FORMAT CSV;) 2025.07.28 06:12:32.942515 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:32.963912 [ 1865 ] {b72d77a9-99d0-44c1-b16c-4f4ce8e94e7f} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 699, line 699) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt8(1) - N as r FORMAT CSV;) 2025.07.28 06:12:32.965245 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:33.243134 [ 1865 ] {3e5de9bb-bf40-425c-9c1d-5d604b1e3ea9} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 707, line 707) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) - N as r FORMAT CSV;) 2025.07.28 06:12:33.259294 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:33.270830 [ 1865 ] {4fa7c8f1-ce60-4f7e-94e0-1a914509280a} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 708, line 708) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt8(-1) - N as r FORMAT CSV;) 2025.07.28 06:12:33.284548 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:33.305479 [ 1865 ] {1046406c-6061-4c1c-b1a9-bfafba714c8f} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 709, line 709) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt8(-1) - N as r FORMAT CSV;) 2025.07.28 06:12:33.315039 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:33.505573 [ 1865 ] {e5c8f5c5-ba40-49bb-9728-75b0f95e9fb1} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 717, line 717) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) - N as r FORMAT CSV;) 2025.07.28 06:12:33.506917 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:33.526071 [ 1865 ] {730da191-dde8-4b01-8f88-ff0311ce60f6} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 718, line 718) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt16(1) - N as r FORMAT CSV;) 2025.07.28 06:12:33.528839 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:33.550539 [ 1865 ] {052be2dc-3371-4366-a13f-43807f294486} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 719, line 719) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt16(1) - N as r FORMAT CSV;) 2025.07.28 06:12:33.554220 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:33.757547 [ 1865 ] {086d73c2-881b-40fb-9055-5ae37d10daeb} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 727, line 727) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) - N as r FORMAT CSV;) 2025.07.28 06:12:33.760709 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:33.786299 [ 1865 ] {37398d53-c234-441b-b6a4-d97305f0c497} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 728, line 728) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt16(-1) - N as r FORMAT CSV;) 2025.07.28 06:12:33.790670 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:33.812277 [ 1865 ] {9355b715-b5b9-4712-bb3b-7027d6ed68fe} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 729, line 729) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt16(-1) - N as r FORMAT CSV;) 2025.07.28 06:12:33.813628 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:34.065034 [ 1865 ] {ba521264-3e6f-473e-839c-40d136e1578c} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 737, line 737) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) - N as r FORMAT CSV;) 2025.07.28 06:12:34.068387 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:34.086073 [ 1865 ] {6be6506d-e272-4bdc-990e-bd5417e0cae8} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 738, line 738) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt32(1) - N as r FORMAT CSV;) 2025.07.28 06:12:34.091195 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:34.107117 [ 1865 ] {781d7b6e-d1d6-4f11-a505-1b67f2a418d7} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 739, line 739) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt32(1) - N as r FORMAT CSV;) 2025.07.28 06:12:34.112438 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:34.305784 [ 1865 ] {f1db3814-d14a-4240-b100-bf6e94e8e490} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 747, line 747) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) - N as r FORMAT CSV;) 2025.07.28 06:12:34.306499 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:34.328379 [ 1865 ] {81dfdeb7-4437-46ac-b3a9-d9425bf50e6b} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 748, line 748) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt32(-1) - N as r FORMAT CSV;) 2025.07.28 06:12:34.329236 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:34.350587 [ 1865 ] {26b99d1b-7c66-4659-8c4a-32e4a3eae14a} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 749, line 749) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt32(-1) - N as r FORMAT CSV;) 2025.07.28 06:12:34.352087 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:34.776285 [ 1865 ] {49f14733-9fb9-4c7d-89b6-004bb6f63fae} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 757, line 757) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) - N as r FORMAT CSV;) 2025.07.28 06:12:34.788950 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:34.801069 [ 1865 ] {31478145-f66d-4e85-aeb3-d81f29b7fed6} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 758, line 758) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt64(1) - N as r FORMAT CSV;) 2025.07.28 06:12:34.802669 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:34.823890 [ 1865 ] {b06c9580-18e6-4ee4-aa40-fd84153c475d} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 759, line 759) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt64(1) - N as r FORMAT CSV;) 2025.07.28 06:12:34.825730 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:35.058954 [ 1865 ] {b6808123-1fa0-4a2d-ba28-6bbbddb3b3a7} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 767, line 767) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) - N as r FORMAT CSV;) 2025.07.28 06:12:35.060321 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:35.081006 [ 1865 ] {7397a3bf-7d3a-405a-aeae-0c1ba7b694f3} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 768, line 768) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt64(-1) - N as r FORMAT CSV;) 2025.07.28 06:12:35.082251 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:35.105255 [ 1865 ] {b849ee57-e6c7-464c-8df9-4db320b4eda6} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 769, line 769) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt64(-1) - N as r FORMAT CSV;) 2025.07.28 06:12:35.106798 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:35.173534 [ 1865 ] {c2c8072d-a05d-41b3-8465-5ff5b52b3fb4} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 772, line 772) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt8(1) as r FORMAT CSV;) 2025.07.28 06:12:35.188493 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:35.325617 [ 1865 ] {b5ce3715-69cd-4eff-aca2-5dda5dad8b7a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 777, line 777) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) == N as r FORMAT CSV;) 2025.07.28 06:12:35.330579 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:35.461387 [ 1865 ] {6da57220-6504-44ee-b18d-f2ce7a8c4d97} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 782, line 782) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt8(-1) as r FORMAT CSV;) 2025.07.28 06:12:35.471647 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:35.610971 [ 1865 ] {bc2e52aa-989d-43aa-8790-d2d424042805} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 787, line 787) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) == N as r FORMAT CSV;) 2025.07.28 06:12:35.613058 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:35.726266 [ 1865 ] {bd20a961-f00e-41fb-bff4-c683d04ce77e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 792, line 792) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt16(1) as r FORMAT CSV;) 2025.07.28 06:12:35.730579 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:35.869547 [ 1865 ] {0a1a7647-5861-40b6-81c6-c5df9c7a3c61} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 797, line 797) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) == N as r FORMAT CSV;) 2025.07.28 06:12:35.871293 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:36.008346 [ 1865 ] {525c3287-bfac-499b-9534-0a1220b67668} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 802, line 802) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt16(-1) as r FORMAT CSV;) 2025.07.28 06:12:36.010263 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:36.140679 [ 1865 ] {ac9778d7-b9b9-40cd-b382-094ab441c6b0} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 807, line 807) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) == N as r FORMAT CSV;) 2025.07.28 06:12:36.142005 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:36.266210 [ 1865 ] {1dfb4c68-10ad-4b62-828e-c8ce201f5ef6} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 812, line 812) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt32(1) as r FORMAT CSV;) 2025.07.28 06:12:36.267394 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:36.395777 [ 1865 ] {4d823125-428d-4bef-92d7-f83dee8d2518} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 817, line 817) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) == N as r FORMAT CSV;) 2025.07.28 06:12:36.397849 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:36.543981 [ 1865 ] {47df7dc6-a186-4a97-bb6f-588e4aa2e7cc} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 822, line 822) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt32(-1) as r FORMAT CSV;) 2025.07.28 06:12:36.544684 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:36.675060 [ 1865 ] {2e65e5e2-2fb9-4a37-bb40-a3267f676ad4} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 827, line 827) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) == N as r FORMAT CSV;) 2025.07.28 06:12:36.681349 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:36.800411 [ 1865 ] {c53c8e23-eb52-4b31-8cae-7ee357556c68} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 832, line 832) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt64(1) as r FORMAT CSV;) 2025.07.28 06:12:36.802847 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:36.930104 [ 1865 ] {d7b5c344-70c5-49f4-9b59-65dfb3685d5a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 837, line 837) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) == N as r FORMAT CSV;) 2025.07.28 06:12:36.930970 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:37.065099 [ 1865 ] {d47be69c-685d-47e5-affc-b28fccc0d3e1} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 842, line 842) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt64(-1) as r FORMAT CSV;) 2025.07.28 06:12:37.067336 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:37.184569 [ 1865 ] {75f61cee-83b5-4b7f-8917-5e10f396d829} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 847, line 847) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) == N as r FORMAT CSV;) 2025.07.28 06:12:37.187765 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:37.350228 [ 1865 ] {e79a248f-30ba-43d4-84e5-2d5bdc4673dc} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 852, line 852) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt8(1) as r FORMAT CSV;) 2025.07.28 06:12:37.351473 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:37.486302 [ 1865 ] {1164c66b-0e3e-41a6-9bbd-23b17b728c9f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 857, line 857) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) != N as r FORMAT CSV;) 2025.07.28 06:12:37.487276 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:37.619152 [ 1865 ] {b42f8ba6-1c53-4da1-a2d5-bf5223d16277} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 862, line 862) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt8(-1) as r FORMAT CSV;) 2025.07.28 06:12:37.620805 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:37.725196 [ 1865 ] {cb669d94-882c-4dab-b011-b43bb7c835b2} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 867, line 867) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) != N as r FORMAT CSV;) 2025.07.28 06:12:37.726137 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:37.838182 [ 1865 ] {958ae90b-e15f-40e2-850b-220a33a306c3} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 872, line 872) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt16(1) as r FORMAT CSV;) 2025.07.28 06:12:37.840239 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:37.962668 [ 1865 ] {bfc88895-f007-4485-88ee-76707f48a8af} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 877, line 877) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) != N as r FORMAT CSV;) 2025.07.28 06:12:37.970211 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:38.088175 [ 1865 ] {a0f38bdf-381d-415f-a026-025e20d8abef} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 882, line 882) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt16(-1) as r FORMAT CSV;) 2025.07.28 06:12:38.089108 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:38.215536 [ 1865 ] {4be1e92d-e216-4c6c-891f-7089c3a81aa9} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 887, line 887) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) != N as r FORMAT CSV;) 2025.07.28 06:12:38.216434 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:38.535421 [ 1865 ] {4166112a-32ca-4d36-953f-a0b61ac16d80} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 892, line 892) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt32(1) as r FORMAT CSV;) 2025.07.28 06:12:38.538847 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:38.652511 [ 1865 ] {b60e4eca-197c-45d6-bfee-20492e0172f5} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 897, line 897) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) != N as r FORMAT CSV;) 2025.07.28 06:12:38.654562 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:38.754790 [ 1865 ] {a22e8a5c-9725-4e3a-8d0a-4c712227c295} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 902, line 902) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt32(-1) as r FORMAT CSV;) 2025.07.28 06:12:38.757046 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:38.867526 [ 1865 ] {d20d678a-a00b-4ad1-b47c-207b9ac8e36f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 907, line 907) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) != N as r FORMAT CSV;) 2025.07.28 06:12:38.868474 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:38.998165 [ 1865 ] {a8652891-ec5b-414c-bac9-f8eaeac98b9f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 912, line 912) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt64(1) as r FORMAT CSV;) 2025.07.28 06:12:38.999097 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:39.112633 [ 1865 ] {24fb7d64-cb4c-4508-948c-3e2a4a34ed28} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 917, line 917) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) != N as r FORMAT CSV;) 2025.07.28 06:12:39.120942 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:39.249454 [ 1865 ] {b2a6b8af-20da-423b-8fe8-65f60846a2c4} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 922, line 922) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt64(-1) as r FORMAT CSV;) 2025.07.28 06:12:39.254817 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:39.370588 [ 1865 ] {15e45aee-8df1-47e5-9b8f-742a267d7868} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 927, line 927) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) != N as r FORMAT CSV;) 2025.07.28 06:12:39.371685 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:39.489248 [ 1865 ] {dfaecb8f-f0e8-4258-8bb5-d33efd84da25} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 932, line 932) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt8(1) as r FORMAT CSV;) 2025.07.28 06:12:39.491123 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:39.602061 [ 1865 ] {f019beaf-c677-4853-b8ce-47745f07ebea} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 937, line 937) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) < N as r FORMAT CSV;) 2025.07.28 06:12:39.603923 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:39.705392 [ 1865 ] {935fa263-8bba-4e13-84f6-d19f7802024f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 942, line 942) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt8(-1) as r FORMAT CSV;) 2025.07.28 06:12:39.707554 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:39.813018 [ 1865 ] {318e2770-6de2-4b46-b678-ec1eb2ea6a37} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 947, line 947) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) < N as r FORMAT CSV;) 2025.07.28 06:12:39.813943 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:39.925438 [ 1865 ] {44beee9f-5b11-4236-a71f-79547272d42b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 952, line 952) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt16(1) as r FORMAT CSV;) 2025.07.28 06:12:39.926571 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:40.046684 [ 1865 ] {9ea498e8-4b04-40e6-8cac-e0bc6323bd76} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 957, line 957) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) < N as r FORMAT CSV;) 2025.07.28 06:12:40.047836 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:40.164571 [ 1865 ] {1262df6d-f713-409a-99e7-17ab3a388bdc} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 962, line 962) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt16(-1) as r FORMAT CSV;) 2025.07.28 06:12:40.165766 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:40.290005 [ 1865 ] {5bc5abd0-5a04-4b7f-b3ec-818f1b80411a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 967, line 967) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) < N as r FORMAT CSV;) 2025.07.28 06:12:40.292103 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:40.395094 [ 1865 ] {50788d1e-3cd0-492a-bbe5-a4b801fdf711} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 972, line 972) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt32(1) as r FORMAT CSV;) 2025.07.28 06:12:40.397690 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:40.505983 [ 1865 ] {ed42d705-2f56-4ab1-913d-3ed53b62e48c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 977, line 977) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) < N as r FORMAT CSV;) 2025.07.28 06:12:40.513648 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:40.623959 [ 1865 ] {99ea2186-2c06-4377-a068-9dd1b9534874} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 982, line 982) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt32(-1) as r FORMAT CSV;) 2025.07.28 06:12:40.625014 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:40.770592 [ 1865 ] {5795ca47-d0b7-4138-9694-12635bce4f77} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 987, line 987) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) < N as r FORMAT CSV;) 2025.07.28 06:12:40.771930 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:40.887101 [ 1865 ] {a818d92a-dbcc-42b8-ba18-ea9ae4ce1c16} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 992, line 992) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt64(1) as r FORMAT CSV;) 2025.07.28 06:12:40.896513 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:41.015619 [ 1865 ] {f39712df-2e88-49d4-ba5e-49b2fc4d9a17} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 997, line 997) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) < N as r FORMAT CSV;) 2025.07.28 06:12:41.023822 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:41.122910 [ 1865 ] {7b71e1ea-f2f5-4231-97d0-1d712df89c44} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1002, line 1002) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt64(-1) as r FORMAT CSV;) 2025.07.28 06:12:41.123865 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:41.231840 [ 1865 ] {9a9b5def-7aa8-463c-8be0-3f50c78f4d92} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1007, line 1007) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) < N as r FORMAT CSV;) 2025.07.28 06:12:41.232876 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:41.356774 [ 1865 ] {afbbc063-e49b-4756-a13f-173ff589c840} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1012, line 1012) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt8(1) as r FORMAT CSV;) 2025.07.28 06:12:41.358415 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:41.658759 [ 1865 ] {f644ed10-d740-4cb1-bd02-6f9141aa248c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1017, line 1017) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) <= N as r FORMAT CSV;) 2025.07.28 06:12:41.662416 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:41.819130 [ 1865 ] {ef272f10-b7e0-4604-aaf6-3ecb0c79d750} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1022, line 1022) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt8(-1) as r FORMAT CSV;) 2025.07.28 06:12:41.825349 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:41.960928 [ 1865 ] {461a1ddd-095d-41ea-b7db-4535266f0dfc} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1027, line 1027) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) <= N as r FORMAT CSV;) 2025.07.28 06:12:41.962535 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:42.116032 [ 1865 ] {be06f899-1071-4d02-b0c7-c497e49dd223} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1032, line 1032) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt16(1) as r FORMAT CSV;) 2025.07.28 06:12:42.117590 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:42.288937 [ 1865 ] {db365d6a-8a5f-418a-9650-4ff71e014651} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1037, line 1037) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) <= N as r FORMAT CSV;) 2025.07.28 06:12:42.290095 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:42.445772 [ 1865 ] {23e2ea6d-5ef7-49c2-b6c1-80001169603e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1042, line 1042) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt16(-1) as r FORMAT CSV;) 2025.07.28 06:12:42.452667 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:42.614041 [ 1865 ] {75d98b43-6457-4a24-903f-d0574ebc7113} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1047, line 1047) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) <= N as r FORMAT CSV;) 2025.07.28 06:12:42.620685 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:42.748843 [ 1865 ] {04b07971-c24b-4dd0-849f-96b582dc87b1} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1052, line 1052) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt32(1) as r FORMAT CSV;) 2025.07.28 06:12:42.750955 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:42.868590 [ 1865 ] {b0a74e35-7a7b-4e85-9954-3a2f609892b0} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1057, line 1057) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) <= N as r FORMAT CSV;) 2025.07.28 06:12:42.872827 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:42.992088 [ 1865 ] {55518150-059d-457f-826e-a47e1c894892} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1062, line 1062) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt32(-1) as r FORMAT CSV;) 2025.07.28 06:12:42.995014 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:43.130337 [ 1865 ] {556be15d-84b1-40e9-847c-a426e0df2da5} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1067, line 1067) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) <= N as r FORMAT CSV;) 2025.07.28 06:12:43.131609 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:43.241376 [ 1865 ] {9283aa36-d851-4d50-afb4-4c8a58efba2c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1072, line 1072) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt64(1) as r FORMAT CSV;) 2025.07.28 06:12:43.242059 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:43.360182 [ 1865 ] {874abf06-ac8a-4921-8e17-c87ef974fbe2} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1077, line 1077) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) <= N as r FORMAT CSV;) 2025.07.28 06:12:43.366067 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:43.475333 [ 1865 ] {66fe623a-f752-4664-bff0-7034b7f07c64} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1082, line 1082) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt64(-1) as r FORMAT CSV;) 2025.07.28 06:12:43.478207 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:43.583706 [ 1865 ] {85e0928f-87a8-4ee8-bc9a-9a2646a9d69e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1087, line 1087) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) <= N as r FORMAT CSV;) 2025.07.28 06:12:43.585821 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:43.706436 [ 1865 ] {bb705d4b-d83d-4d26-82c1-9054c7f848c4} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1092, line 1092) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt8(1) as r FORMAT CSV;) 2025.07.28 06:12:43.707203 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:43.811984 [ 1865 ] {f09af855-3423-4658-8499-87b996e7075c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1097, line 1097) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) > N as r FORMAT CSV;) 2025.07.28 06:12:43.814578 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:43.924643 [ 1865 ] {2073cfa1-b918-4bd3-b1a2-e4ece08bb4b1} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1102, line 1102) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt8(-1) as r FORMAT CSV;) 2025.07.28 06:12:43.927028 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:44.044279 [ 1865 ] {def7a0b0-b3b7-41ff-b4d6-3ac253c1c079} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1107, line 1107) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) > N as r FORMAT CSV;) 2025.07.28 06:12:44.045015 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:44.147532 [ 1865 ] {1e6952e5-f831-485f-b34e-9c23d3b0a37e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1112, line 1112) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt16(1) as r FORMAT CSV;) 2025.07.28 06:12:44.150508 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:44.247386 [ 1865 ] {cfc3c31b-66a5-4f47-9daf-6f79598f39af} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1117, line 1117) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) > N as r FORMAT CSV;) 2025.07.28 06:12:44.249408 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:44.353388 [ 1865 ] {788082c4-1da6-4ae6-8c46-3c969e52c163} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1122, line 1122) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt16(-1) as r FORMAT CSV;) 2025.07.28 06:12:44.354482 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:44.459709 [ 1865 ] {b4e1a724-6953-41c4-b29f-54122e518cbf} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1127, line 1127) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) > N as r FORMAT CSV;) 2025.07.28 06:12:44.463592 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:44.588276 [ 1865 ] {c9be66cf-1868-411a-8f98-dd03b96c847f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1132, line 1132) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt32(1) as r FORMAT CSV;) 2025.07.28 06:12:44.591922 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:44.686164 [ 1865 ] {a394b7fa-41d6-4ffb-a626-17cd081e5e17} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1137, line 1137) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) > N as r FORMAT CSV;) 2025.07.28 06:12:44.686908 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:44.780917 [ 1865 ] {7bb0f07d-b14b-4fdb-866d-553144736e69} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1142, line 1142) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt32(-1) as r FORMAT CSV;) 2025.07.28 06:12:44.782547 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:44.878240 [ 1865 ] {dd0f4311-e5d4-4b1b-8bda-5e9ea7688621} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1147, line 1147) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) > N as r FORMAT CSV;) 2025.07.28 06:12:44.880241 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:44.977381 [ 1865 ] {e7ac24c5-493f-40d9-8731-f3a431ba020e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1152, line 1152) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt64(1) as r FORMAT CSV;) 2025.07.28 06:12:44.980645 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:45.070742 [ 1865 ] {128688d2-cef1-4e24-8090-20ef0712949c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1157, line 1157) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) > N as r FORMAT CSV;) 2025.07.28 06:12:45.073562 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:45.184112 [ 1865 ] {20a54e9f-c6c0-4d33-8048-aae2de9cf85c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1162, line 1162) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt64(-1) as r FORMAT CSV;) 2025.07.28 06:12:45.190556 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:45.285090 [ 1865 ] {6a0e99ca-0882-4a98-8a00-09a69a88807f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1167, line 1167) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) > N as r FORMAT CSV;) 2025.07.28 06:12:45.286912 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:45.382634 [ 1865 ] {38013b79-176b-45e5-842e-eab75ae6d880} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1172, line 1172) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt8(1) as r FORMAT CSV;) 2025.07.28 06:12:45.384521 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:45.487941 [ 1865 ] {660a02dc-fdc1-4f9b-9512-6300fe387b92} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1177, line 1177) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) >= N as r FORMAT CSV;) 2025.07.28 06:12:45.490570 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:45.578973 [ 1865 ] {557cc8c3-42a1-4aeb-80d3-a6f61e3b7910} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1182, line 1182) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt8(-1) as r FORMAT CSV;) 2025.07.28 06:12:45.579696 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:45.696003 [ 1865 ] {922cc99a-e61f-498e-9887-d8432c5846e6} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1187, line 1187) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) >= N as r FORMAT CSV;) 2025.07.28 06:12:45.697707 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:45.791237 [ 1865 ] {d1dbab5e-1bd4-4a08-8b20-9e74d2c30f6d} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1192, line 1192) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt16(1) as r FORMAT CSV;) 2025.07.28 06:12:45.792300 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:45.899765 [ 1865 ] {b934ae09-ffb6-4264-ac2b-154fb378dc1b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1197, line 1197) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) >= N as r FORMAT CSV;) 2025.07.28 06:12:45.900820 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:46.002796 [ 1865 ] {522d3187-4d0b-45c1-b9c9-8168ef03d022} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1202, line 1202) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt16(-1) as r FORMAT CSV;) 2025.07.28 06:12:46.005460 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:46.101172 [ 1865 ] {a4dfb914-910d-4a75-9734-adef7fce7759} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1207, line 1207) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) >= N as r FORMAT CSV;) 2025.07.28 06:12:46.104380 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:46.188578 [ 1865 ] {a9e4f043-2ccc-42f4-9a45-022929e8e0ae} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1212, line 1212) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt32(1) as r FORMAT CSV;) 2025.07.28 06:12:46.190160 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:46.279394 [ 1865 ] {3e77c714-f694-4d51-a38a-e66721b9f7af} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1217, line 1217) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) >= N as r FORMAT CSV;) 2025.07.28 06:12:46.280644 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:46.387099 [ 1865 ] {c91ad1de-2705-4962-8140-46e4905ea14b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1222, line 1222) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt32(-1) as r FORMAT CSV;) 2025.07.28 06:12:46.388705 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:46.483599 [ 1865 ] {8a9f8b3c-ac01-46b3-8e1e-3f2637bd14c1} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1227, line 1227) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) >= N as r FORMAT CSV;) 2025.07.28 06:12:46.488696 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:46.578924 [ 1865 ] {49279feb-e435-41f3-80ba-0b067af4b3b4} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1232, line 1232) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt64(1) as r FORMAT CSV;) 2025.07.28 06:12:46.581721 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:46.681045 [ 1865 ] {119215cb-b0ac-44bd-b27a-071b00d57762} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1237, line 1237) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) >= N as r FORMAT CSV;) 2025.07.28 06:12:46.683887 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:46.775718 [ 1865 ] {01eafccc-1911-4fe2-b730-fb74857261f5} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1242, line 1242) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt64(-1) as r FORMAT CSV;) 2025.07.28 06:12:46.778540 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:47.050685 [ 1865 ] {8d8907c2-2af1-4133-979d-e3dd9bda932f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36528) (comment: 00921_datetime64_compatibility_long.sh) (query 1247, line 1247) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) >= N as r FORMAT CSV;) 2025.07.28 06:12:47.052084 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.07.28 06:12:50.159241 [ 2064 ] {1caff6c1-57ca-4a79-82fb-3d45092d684f} executeQuery: Code: 43. DB::Exception: The timezone argument of function toMonday is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toMonday(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59148) (comment: 00189_time_zones_long.sql) (query 18, line 36) (in query: SELECT toMonday(toDate(16433), 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000ee150b1 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ee6b9ce 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:50.162392 [ 2064 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toMonday is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toMonday(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000ee150b1 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ee6b9ce 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:50.463856 [ 2064 ] {34f2e37d-6b14-4380-bcd2-c0c4f7e2a202} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toStartOfWeek(toDate(16433), 0, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59148) (comment: 00189_time_zones_long.sql) (query 26, line 47) (in query: SELECT toStartOfWeek(toDate(16433), 0, 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000ee2eb86 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ee2b60c 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:50.465295 [ 2064 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toStartOfWeek(toDate(16433), 0, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000ee2eb86 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ee2b60c 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:50.612661 [ 2064 ] {d585eae4-0b14-4452-868c-139b98d9b844} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toStartOfWeek(toDate(16433), 1, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59148) (comment: 00189_time_zones_long.sql) (query 34, line 58) (in query: SELECT toStartOfWeek(toDate(16433), 1, 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000ee2eb86 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ee2b60c 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:50.613810 [ 2064 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toStartOfWeek(toDate(16433), 1, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000ee2eb86 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ee2b60c 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:50.955167 [ 2064 ] {cdb6fc87-afde-442d-9360-79e7194c85de} executeQuery: Code: 43. DB::Exception: The timezone argument of function toLastDayOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toLastDayOfWeek(toDate(16433), 0, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59148) (comment: 00189_time_zones_long.sql) (query 42, line 69) (in query: SELECT toLastDayOfWeek(toDate(16433), 0, 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000ee32d26 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ee2faac 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:50.956340 [ 2064 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toLastDayOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toLastDayOfWeek(toDate(16433), 0, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000ee32d26 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ee2faac 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:51.118677 [ 2064 ] {d802509a-825c-48c4-8c23-00df07f90854} executeQuery: Code: 43. DB::Exception: The timezone argument of function toLastDayOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toLastDayOfWeek(toDate(16433), 1, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59148) (comment: 00189_time_zones_long.sql) (query 50, line 80) (in query: SELECT toLastDayOfWeek(toDate(16433), 1, 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000ee32d26 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ee2faac 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:51.119678 [ 2064 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toLastDayOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toLastDayOfWeek(toDate(16433), 1, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x000000000ee32d26 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ee2faac 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:51.387862 [ 2064 ] {1255649e-47a1-4126-96c2-ee2d150c210e} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfMonth is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toStartOfMonth(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59148) (comment: 00189_time_zones_long.sql) (query 58, line 91) (in query: SELECT toStartOfMonth(toDate(16433), 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000ee150b1 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eef97ee 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:51.389130 [ 2064 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfMonth is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toStartOfMonth(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000ee150b1 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eef97ee 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:51.645338 [ 2064 ] {f81cf566-b0c6-406e-8473-3ec77d31b9ae} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfQuarter is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toStartOfQuarter(toDate(16343), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59148) (comment: 00189_time_zones_long.sql) (query 66, line 102) (in query: SELECT toStartOfQuarter(toDate(16343), 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000ee150b1 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eefcb4e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:51.646339 [ 2064 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfQuarter is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toStartOfQuarter(toDate(16343), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000ee150b1 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eefcb4e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:51.943011 [ 2064 ] {b1277192-711a-4f6d-b761-2c6d1de0e8d8} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toStartOfYear(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59148) (comment: 00189_time_zones_long.sql) (query 74, line 113) (in query: SELECT toStartOfYear(toDate(16433), 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000ee150b1 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ef0b34e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:51.945320 [ 2064 ] {} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toStartOfYear(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000ee150b1 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ef0b34e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:12:52.451648 [ 2061 ] {55a86387-d4ec-4bcd-8ea8-eb634779d80d} executeQuery: Code: 59. DB::Exception: Illegal type Int128 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59254) (comment: 02473_prewhere_with_bigint.sql) (query 7, line 8) (in query: SELECT a FROM prewhere_int128 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x000000001c467e41 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001b571e3e 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000001c39b475 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x000000001b45c2be 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x000000001b4403ac 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x000000001b440087 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001b7b2bcf 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa683 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:12:52.452851 [ 2061 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type Int128 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x000000001c467e41 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001b571e3e 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000001c39b475 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x000000001b45c2be 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x000000001b4403ac 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x000000001b440087 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001b7b2bcf 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa683 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:12:52.725902 [ 2061 ] {a9c0737b-8903-40db-8760-4491899b58cf} executeQuery: Code: 59. DB::Exception: Illegal type Int256 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59254) (comment: 02473_prewhere_with_bigint.sql) (query 11, line 13) (in query: SELECT a FROM prewhere_int256 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x000000001c467e41 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001b571e3e 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000001c39b475 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x000000001b45c2be 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x000000001b4403ac 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x000000001b440087 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001b7b2bcf 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa683 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:12:52.729153 [ 2061 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type Int256 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x000000001c467e41 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001b571e3e 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000001c39b475 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x000000001b45c2be 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x000000001b4403ac 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x000000001b440087 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001b7b2bcf 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa683 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:12:52.849040 [ 2061 ] {b9ef581e-651e-488c-ae36-c07207b4fe39} executeQuery: Code: 59. DB::Exception: Illegal type UInt128 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59254) (comment: 02473_prewhere_with_bigint.sql) (query 15, line 18) (in query: SELECT a FROM prewhere_uint128 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x000000001c467e41 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001b571e3e 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000001c39b475 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x000000001b45c2be 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x000000001b4403ac 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x000000001b440087 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001b7b2bcf 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa683 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:12:52.851091 [ 2061 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type UInt128 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x000000001c467e41 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001b571e3e 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000001c39b475 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x000000001b45c2be 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x000000001b4403ac 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x000000001b440087 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001b7b2bcf 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa683 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:12:52.976781 [ 2061 ] {8fec0014-3703-4b02-adbd-94f71587d5b3} executeQuery: Code: 59. DB::Exception: Illegal type UInt256 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59254) (comment: 02473_prewhere_with_bigint.sql) (query 19, line 23) (in query: SELECT a FROM prewhere_uint256 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x000000001c467e41 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001b571e3e 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000001c39b475 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x000000001b45c2be 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x000000001b4403ac 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x000000001b440087 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001b7b2bcf 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa683 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:12:52.981113 [ 2061 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type UInt256 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x000000001c467e41 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001b571e3e 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000001c39b475 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x000000001b45c2be 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x000000001b4403ac 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x000000001b440087 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001b7b2bcf 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa683 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:12:54.612053 [ 1861 ] {05d4a4eb-00d9-4fce-be4e-574e79052596} executeQuery: Code: 277. DB::Exception: Primary key (i) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59310) (comment: 02950_part_offset_as_primary_key.sql) (query 13, line 22) (in query: -- the force_primary_key check still works select i from a where _part_offset = 4 order by i settings force_primary_key = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000001ab15bc0 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1759: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b1216 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3bb568 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:12:54.613532 [ 1861 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (i) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000001ab15bc0 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1759: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b1216 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3bb568 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:12:54.636443 [ 1861 ] {7ff6cfca-827d-4cb7-ba72-5832dcbe60cb} executeQuery: Code: 277. DB::Exception: Primary key (i) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59310) (comment: 02950_part_offset_as_primary_key.sql) (query 14, line 25) (in query: -- combining with other primary keys doesn't work (makes no sense) select i from a where i = -3 or _part_offset = 4 order by i settings force_primary_key = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000001ab15bc0 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1759: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b1216 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3bb568 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:12:54.638017 [ 1861 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (i) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x000000001ab15bc0 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1759: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b1216 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3bb568 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:13:01.756275 [ 1859 ] {ec5e9e21-fa1f-40d6-b339-ad10223eb896} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUUID(-1.1). (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42372) (comment: 01634_uuid_fuzz.sql) (query 1, line 1) (in query: SELECT toUUID(-1.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1716: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeUUID, DB::detail::NameToUUID, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000016331d3d 5. ./src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161e162c 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016209aa7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016209040 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:13:01.757676 [ 1859 ] {} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUUID(-1.1). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1716: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeUUID, DB::detail::NameToUUID, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000016331d3d 5. ./src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161e162c 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016209aa7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016209040 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:13:02.797442 [ 1861 ] {1722cb2a-54eb-45f8-8d57-69a558c65be3} executeQuery: Code: 44. DB::Exception: Cannot drop column `id`, because column `id2` depends on it. (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42460) (comment: 00575_illegal_column_exception_when_drop_depen_column.sh) (query 1, line 1) (in query: ALTER TABLE test_00575 DROP COLUMN id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Storages/AlterCommands.cpp:1606: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9defa2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:13:02.814919 [ 1861 ] {} TCPHandler: Code: 44. DB::Exception: Cannot drop column `id`, because column `id2` depends on it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Storages/AlterCommands.cpp:1606: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9defa2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:13:07.273311 [ 1856 ] {f7af6bcf-b35d-45d5-8b3e-59fc7b96e401} executeQuery: Code: 370. DB::Exception: Data type Nullable(Nothing) of column 'x' cannot be used in tables. (DATA_TYPE_CANNOT_BE_USED_IN_TABLES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42610) (comment: 03243_check_for_nullable_nothing_in_alter.sql) (query 5, line 5) (in query: alter table src modify column x Nullable(Nothing);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Storages/StorageFactory.cpp:36: DB::checkAllTypesAreAllowedInTable(DB::NamesAndTypesList const&) @ 0x000000001aab1a59 5. ./build_docker/./src/Storages/AlterCommands.cpp:1534: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9dd24f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:13:07.276207 [ 1856 ] {} TCPHandler: Code: 370. DB::Exception: Data type Nullable(Nothing) of column 'x' cannot be used in tables. (DATA_TYPE_CANNOT_BE_USED_IN_TABLES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Storages/StorageFactory.cpp:36: DB::checkAllTypesAreAllowedInTable(DB::NamesAndTypesList const&) @ 0x000000001aab1a59 5. ./build_docker/./src/Storages/AlterCommands.cpp:1534: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9dd24f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:13:07.445142 [ 1856 ] {50386b95-ba32-461f-b655-029c59822dfa} executeQuery: Code: 370. DB::Exception: Data type Nullable(Nothing) of column 'x' cannot be used in tables. (DATA_TYPE_CANNOT_BE_USED_IN_TABLES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42610) (comment: 03243_check_for_nullable_nothing_in_alter.sql) (query 8, line 8) (in query: alter table v modify query select NULL as x from src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Storages/StorageFactory.cpp:36: DB::checkAllTypesAreAllowedInTable(DB::NamesAndTypesList const&) @ 0x000000001aab1a59 5. ./build_docker/./src/Storages/StorageMaterializedView.cpp:650: DB::StorageMaterializedView::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001aba308e 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:13:07.447264 [ 1856 ] {} TCPHandler: Code: 370. DB::Exception: Data type Nullable(Nothing) of column 'x' cannot be used in tables. (DATA_TYPE_CANNOT_BE_USED_IN_TABLES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Storages/StorageFactory.cpp:36: DB::checkAllTypesAreAllowedInTable(DB::NamesAndTypesList const&) @ 0x000000001aab1a59 5. ./build_docker/./src/Storages/StorageMaterializedView.cpp:650: DB::StorageMaterializedView::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001aba308e 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:13:08.850387 [ 1851 ] {dbce07ae-e975-4a54-b054-783419f4d540} executeQuery: Code: 43. DB::Exception: First argument for function tupleNames must be a tuple: In scope SELECT tupleNames(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58738) (comment: 02890_named_tuple_functions.sql) (query 14, line 20) (in query: select tupleNames(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::TupleNamesOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ef9e7fc 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:13:08.851835 [ 1851 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleNames must be a tuple: In scope SELECT tupleNames(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::TupleNamesOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ef9e7fc 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:13:09.267110 [ 1859 ] {b6a02082-3764-45cf-96f4-94ec5c92403c} executeQuery: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58720) (comment: 00203_full_join.sql) (query 22, line 29) (in query: SELECT k1, k2, k3, val_t1, val_t2 FROM t1_00203 ANY FULL JOIN t2_00203 USING (k3, k1, k2) ORDER BY k1, k2, k3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:997: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a4f3af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a425e4 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a46116 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a424f6 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000017a4218a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b0e7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:13:09.273291 [ 1859 ] {} TCPHandler: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:997: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a4f3af 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a425e4 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a46116 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a424f6 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000017a4218a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b0e7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:13:09.730501 [ 2052 ] {cfccb396-230e-4522-ab41-3a2a7a368303} executeQuery: Code: 42. DB::Exception: Table function 'executable' requires minimum 3 arguments: script_name, format, structure, [input_query...]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58780) (comment: 03006_analyzer_executable_table_function.sql) (query 1, line 1) (in query: SELECT toFixedString(toFixedString(toLowCardinality(toFixedString('--------------------', toNullable(20))), toLowCardinality(20)), 20), * FROM executable('data String', SETTINGS max_command_execution_time = 100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:98: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000013cb7fd9 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8aad6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:13:09.732327 [ 2052 ] {} TCPHandler: Code: 42. DB::Exception: Table function 'executable' requires minimum 3 arguments: script_name, format, structure, [input_query...]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:98: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000013cb7fd9 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8aad6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:13:12.422479 [ 1855 ] {8e6ea2f9-0a2b-4047-9ee5-9c8de3299b40} executeQuery: Code: 223. DB::Exception: All elements of Enum data type must be of form: 'name' = number or 'name', where name is string literal and number is an integer. (UNEXPECTED_AST_STRUCTURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58900) (comment: 00757_enum_defaults.sql) (query 15, line 18) (in query: CREATE TABLE auto_assign_enum2 (`x` enum('a' = -1000, 'b', 'c' = -99)) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 63718, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 364601121, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 8637230, merge_max_block_size = 12850, old_parts_lifetime = 366., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10506433941, index_granularity_bytes = 5604463, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 62, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 8217, primary_key_compress_block_size = 36439, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:248: DB::autoAssignNumberForEnum(std::shared_ptr const&) @ 0x0000000017426bd5 5. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:302: DB::create(std::shared_ptr const&) @ 0x0000000017425f30 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:13:12.423986 [ 1855 ] {} TCPHandler: Code: 223. DB::Exception: All elements of Enum data type must be of form: 'name' = number or 'name', where name is string literal and number is an integer. (UNEXPECTED_AST_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:248: DB::autoAssignNumberForEnum(std::shared_ptr const&) @ 0x0000000017426bd5 5. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:302: DB::create(std::shared_ptr const&) @ 0x0000000017425f30 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:13:12.630387 [ 1855 ] {a4ecaae9-64c7-462f-a822-2f79559d9e2c} executeQuery: Code: 223. DB::Exception: Elements of Enum data type must be of form: 'name' = number or 'name', where name is string literal and number is an integer. (UNEXPECTED_AST_STRUCTURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58900) (comment: 00757_enum_defaults.sql) (query 19, line 34) (in query: CREATE TABLE auto_assign_enum3 (`x` enum('a', 'b', NULL)) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 63718, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 364601121, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 8637230, merge_max_block_size = 12850, old_parts_lifetime = 366., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10506433941, index_granularity_bytes = 5604463, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 62, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 8217, primary_key_compress_block_size = 36439, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:280: std::shared_ptr DB::createExact>(DB::IDataType const&) @ 0x0000000017425615 5. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:323: DB::create(std::shared_ptr const&) @ 0x0000000017426100 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:13:12.631909 [ 1855 ] {} TCPHandler: Code: 223. DB::Exception: Elements of Enum data type must be of form: 'name' = number or 'name', where name is string literal and number is an integer. (UNEXPECTED_AST_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:280: std::shared_ptr DB::createExact>(DB::IDataType const&) @ 0x0000000017425615 5. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:323: DB::create(std::shared_ptr const&) @ 0x0000000017426100 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:13:13.603198 [ 2054 ] {dece5343-2c1a-48e1-9298-b7158955e07d} executeQuery: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 4877700000 microseconds per block (of size 97554): while executing 'FUNCTION sleepEachRow(0.05_Float64 :: 1) -> sleepEachRow(0.05_Float64) UInt8 : 0'. (TOO_SLOW) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58956) (comment: 02725_sleep_max_time.sql) (query 1, line 1) (in query: SELECT * FROM system.numbers WHERE sleepEachRow(0.05) LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000000ec47a0c 4. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000ec47859 5. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec46ee7 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:13:13.604946 [ 2054 ] {} TCPHandler: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 4877700000 microseconds per block (of size 97554): while executing 'FUNCTION sleepEachRow(0.05_Float64 :: 1) -> sleepEachRow(0.05_Float64) UInt8 : 0'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000000ec47a0c 4. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000ec47859 5. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec46ee7 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:13:14.516463 [ 1859 ] {aeeb4940-2f0a-4061-889c-018ec7f7a08d} executeQuery: Code: 69. DB::Exception: Cannot convert value '-3': it cannot be represented as UInt128. (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59004) (comment: 02560_with_fill_int256_int.sql) (query 7, line 8) (in query: SELECT (number * 2)::UInt128 FROM numbers(10) ORDER BY 1 ASC WITH FILL FROM -3 TO 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:646: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd801e 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:195: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001c30dbd1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001c30af36 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173aab0f 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173aa83d 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173c62ad 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c30a073 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3285b4 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:13:14.517838 [ 1859 ] {} TCPHandler: Code: 69. DB::Exception: Cannot convert value '-3': it cannot be represented as UInt128. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:646: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd801e 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:195: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001c30dbd1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001c30af36 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173aab0f 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173aa83d 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173c62ad 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c30a073 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3285b4 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:13:14.533834 [ 1859 ] {276ef432-06be-4d68-86a6-974f47da129a} executeQuery: Code: 69. DB::Exception: Cannot convert value '-3': it cannot be represented as UInt256. (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59004) (comment: 02560_with_fill_int256_int.sql) (query 8, line 9) (in query: SELECT (number * 2)::UInt256 FROM numbers(10) ORDER BY 1 ASC WITH FILL FROM -3 TO 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:646: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd801e 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:195: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001c30dbd1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001c30af36 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173aab0f 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173aa83d 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173c62ad 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c30a073 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3285b4 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:13:14.535984 [ 1859 ] {} TCPHandler: Code: 69. DB::Exception: Cannot convert value '-3': it cannot be represented as UInt256. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:646: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd801e 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:195: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001c30dbd1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001c30af36 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173aab0f 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173aa83d 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000173c62ad 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c30a073 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3285b4 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:13:16.711310 [ 1856 ] {e0ad2da6-4200-4a6c-a793-775c1e61249f} executeQuery: Code: 190. DB::Exception: Elements 'NestedColumn.ID' and 'NestedColumn.Count' of Nested data structure 'NestedColumn' (Array columns) have different array sizes. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59090) (comment: 00698_validate_array_sizes_for_nested_kshvakov.sql) (query 4, line 14) (in query: INSERT INTO Issue_2231_Invalid_Nested_Columns_Size VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&) @ 0x00000000174d516c 4. ./build_docker/./src/DataTypes/NestedUtils.cpp:261: DB::Nested::validateArraySizes(DB::Block const&) @ 0x00000000174d2f84 5. ./build_docker/./src/Processors/Transforms/NestedElementsValidationTransform.cpp:13: DB::NestedElementsValidationTransform::transform(DB::Chunk&) @ 0x000000001c0f948b 6. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:13:16.712659 [ 1856 ] {} TCPHandler: Code: 190. DB::Exception: Elements 'NestedColumn.ID' and 'NestedColumn.Count' of Nested data structure 'NestedColumn' (Array columns) have different array sizes. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&) @ 0x00000000174d516c 4. ./build_docker/./src/DataTypes/NestedUtils.cpp:261: DB::Nested::validateArraySizes(DB::Block const&) @ 0x00000000174d2f84 5. ./build_docker/./src/Processors/Transforms/NestedElementsValidationTransform.cpp:13: DB::NestedElementsValidationTransform::transform(DB::Chunk&) @ 0x000000001c0f948b 6. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:13:18.680986 [ 1808 ] {7c65ff00-fce0-4fa5-bde2-8b1593310283} executeQuery: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:32936) (comment: 02947_parallel_replicas_remote.sql) (query 4, line 10) (in query: SELECT count() AS `count()`, sum(`__table1`.`id`) AS `sum(id)` FROM `test_f7thc1nx`.`test` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/Context.cpp:6297: DB::Context::getClusterForParallelReplicas() const @ 0x00000000181d189f 5. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:823: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x000000001a2a9f28 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1012: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa765 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:13:18.683804 [ 1808 ] {} TCPHandler: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/Context.cpp:6297: DB::Context::getClusterForParallelReplicas() const @ 0x00000000181d189f 5. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:823: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x000000001a2a9f28 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1012: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa765 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:13:18.692281 [ 2070 ] {7cd52813-fee4-48c9-a67f-487fc88c30c5} executeQuery: Code: 701. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/Context.cpp:6297: DB::Context::getClusterForParallelReplicas() const @ 0x00000000181d189f 5. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:823: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x000000001a2a9f28 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1012: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa765 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 : While executing Remote. (CLUSTER_DOESNT_EXIST) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57800) (comment: 02947_parallel_replicas_remote.sql) (query 4, line 10) (in query: SELECT count(), sum(id) FROM remote('127.0.0.1|127.0.0.2|127.0.0.3|127.0.0.4', currentDatabase(), test) SETTINGS enable_parallel_replicas = 2, max_parallel_replicas = 4, prefer_localhost_replica = 0, parallel_replicas_for_non_replicated_merge_tree = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010c366ad 3. ./build_docker/./src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x000000001ba2a28b 4. ./build_docker/./src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x000000001ba36553 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001ba9d11e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 2025.07.28 06:13:18.698476 [ 2070 ] {} TCPHandler: Code: 701. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/Context.cpp:6297: DB::Context::getClusterForParallelReplicas() const @ 0x00000000181d189f 5. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:823: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x000000001a2a9f28 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1012: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa765 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 : While executing Remote. (CLUSTER_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010c366ad 3. ./build_docker/./src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x000000001ba2a28b 4. ./build_docker/./src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x000000001ba36553 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001ba9d11e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:13:22.843945 [ 2070 ] {c8a16ec6-e1c2-4a6e-a4d9-b7e8c7b97a98} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(257)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57950) (comment: 02426_create_suspicious_fixed_string.sql) (query 2, line 2) (in query: CREATE TABLE suspicious_fixed_string (`id` UInt64, `s` FixedString(257)) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 12308, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 317021660, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 23605479, merge_max_block_size = 11102, old_parts_lifetime = 22., prefer_fetch_merged_part_size_threshold = 918874007, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 893327594, index_granularity_bytes = 23131401, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 97985, primary_key_compress_block_size = 28291, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x0000000008c90606 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000018e73e2f 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000018e73132 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000188be4ec 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188ba66f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:13:22.846458 [ 2070 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(257)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x0000000008c90606 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000018e73e2f 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000018e73132 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000188be4ec 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188ba66f 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:13:23.279717 [ 3006 ] {e53e9784-f6b6-4422-8b3f-a273413c7b2b} InterpreterCheckQuery: Check query for table test_riaioq7v.tp_1 (080628eb-26b2-4ff7-8618-290cfc7d629f) failed, path 0_5_5_0, reason: Code: 227. DB::Exception: Found unexpected projection directories: pp.proj. (UNEXPECTED_FILE_IN_DATA_PART) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:25.647710 [ 2108 ] {94d108a6-4a6d-473a-92e1-936eff624d18} InterpreterCheckQuery: Check query for table test_riaioq7v.tp_1 (8d3d1c4d-0f7a-4e03-ba35-2d54889e924a) failed, path 0_1_1_0, reason: Code: 227. DB::Exception: Found unexpected projection directories: pp.proj. (UNEXPECTED_FILE_IN_DATA_PART) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:26.137197 [ 1394 ] {f344a344-26c7-4daf-95ce-594210d384b8} InterpreterCheckQuery: Check query for table test_riaioq7v.tp_1 (8d3d1c4d-0f7a-4e03-ba35-2d54889e924a) failed, path 0_1_1_0, reason: Code: 227. DB::Exception: Found unexpected projection directories: pp.proj. (UNEXPECTED_FILE_IN_DATA_PART) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:26.720120 [ 2081 ] {} test_riaioq7v.tp_1 (8d3d1c4d-0f7a-4e03-ba35-2d54889e924a): Cannot quickly remove directory /var/lib/clickhouse/store/8d3/8d3d1c4d-0f7a-4e03-ba35-2d54889e924a/delete_tmp_0_1_1_0/pp.proj by removing files; fallback to recursive removal. Reason: Code: 458. DB::ErrnoException: Cannot unlink file /var/lib/clickhouse/store/8d3/8d3d1c4d-0f7a-4e03-ba35-2d54889e924a/delete_tmp_0_1_1_0/pp.proj/count.txt: , errno: 2, strerror: No such file or directory. (CANNOT_UNLINK) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:34.229691 [ 1861 ] {2322d998-e1b6-4e84-ae17-a478ca248c06} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36938) (comment: 02473_functions_in_readonly_mode.sh) (query 1, line 1) (in query: SELECT * from format('TSV', '123')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d023a0 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x0000000016d00f59 6. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x0000000016cce9da 7. ./src/Access/ContextAccess.h:254: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x000000001819c2d7 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:31: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482581 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:13:34.232234 [ 1861 ] {} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d023a0 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x0000000016d00f59 6. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x0000000016cce9da 7. ./src/Access/ContextAccess.h:254: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x000000001819c2d7 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:31: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482581 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:13:34.853059 [ 1808 ] {fb55ad53-82ac-49ac-a3b3-74c9f1e3b996} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37000) (comment: 02473_functions_in_readonly_mode.sh) (query 1, line 1) (in query: INSERT INTO FUNCTION null('x String') (x) FORMAT TSV ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d023a0 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x0000000016d00f59 6. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x0000000016cce9da 7. ./src/Access/ContextAccess.h:254: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x000000001819c2d7 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:31: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482581 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:153: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000189113b0 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:13:34.855779 [ 1808 ] {} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d023a0 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x0000000016d00f59 6. ./build_docker/./src/Access/ContextAccess.cpp:775: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x0000000016cce9da 7. ./src/Access/ContextAccess.h:254: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x000000001819c2d7 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:31: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482581 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:153: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000189113b0 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:13:35.704350 [ 1859 ] {f82470a9-5d85-4220-b946-51963ea5dd97} executeQuery: Code: 1. DB::Exception: Recursive lambda x -> (lambda(1) + x) AS lambda. In scope x -> (lambda(1) + x) AS lambda. (UNSUPPORTED_METHOD) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37048) (comment: 02388_analyzer_recursive_lambda.sql) (query 2, line 3) (in query: WITH x -> plus(lambda(1), x) AS lambda SELECT lambda(1048576);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2616: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x0000000017ab3c8f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3180: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa41bf 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2671: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x0000000017ab384a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3180: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa41bf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:35.714960 [ 1859 ] {} TCPHandler: Code: 1. DB::Exception: Recursive lambda x -> (lambda(1) + x) AS lambda. In scope x -> (lambda(1) + x) AS lambda. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2616: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x0000000017ab3c8f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3180: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa41bf 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2671: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x0000000017ab384a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3180: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa41bf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:35.748443 [ 1859 ] {b1d5bef7-10ea-4974-9eeb-17b02e274514} executeQuery: Code: 1. DB::Exception: Recursive lambda x -> plus(lambda(1), x, 2) AS lambda. In scope x -> plus(lambda(1), x, 2) AS lambda. (UNSUPPORTED_METHOD) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37048) (comment: 02388_analyzer_recursive_lambda.sql) (query 3, line 5) (in query: WITH lambda(lambda(plus(x, x, -1)), tuple(x), x + 2147483646) AS lambda, x -> plus(lambda(1), x, 2) AS lambda SELECT 1048576, lambda(1048576);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2616: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x0000000017ab3c8f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3180: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa41bf 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2671: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x0000000017ab384a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3180: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa41bf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:35.751807 [ 1859 ] {} TCPHandler: Code: 1. DB::Exception: Recursive lambda x -> plus(lambda(1), x, 2) AS lambda. In scope x -> plus(lambda(1), x, 2) AS lambda. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2616: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x0000000017ab3c8f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3180: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa41bf 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2671: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x0000000017ab384a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3180: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa41bf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:35.932134 [ 1855 ] {bbfa24d1-3020-4f8f-b2f4-64f4ae9ef733} executeQuery: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37032) (comment: 01888_bloom_filter_hasAny.sql) (query 6, line 18) (in query: SELECT count() FROM bftest WHERE hasAny(y, [[123], -42]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dfec5c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000174fb740 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000175001b3 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x00000000174c0d12 7. auto DB::Field::dispatch, DB::Field&>(DB::FieldToDataType<(DB::LeastSupertypeOnError)0>&&, DB::Field&) @ 0x000000000ac9a421 8. ./src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000017969e07 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x0000000017a5a341 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a44528 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a44efa 12. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:364: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a4a5cd 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a425e4 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a46116 15. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a424f6 16. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000017a4218a 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b0e7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:13:35.933433 [ 1855 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dfec5c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000174fb740 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000175001b3 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x00000000174c0d12 7. auto DB::Field::dispatch, DB::Field&>(DB::FieldToDataType<(DB::LeastSupertypeOnError)0>&&, DB::Field&) @ 0x000000000ac9a421 8. ./src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000017969e07 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x0000000017a5a341 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a44528 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a44efa 12. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:364: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a4a5cd 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a425e4 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a46116 15. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a424f6 16. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000017a4218a 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b0e7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:13:36.336802 [ 1855 ] {f156876d-63cf-4278-af6e-f3d7723f36e1} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37032) (comment: 01888_bloom_filter_hasAny.sql) (query 13, line 27) (in query: -- can't use bloom_filter with `hasAny` on non-constant arguments (just like `has`) SELECT count() FROM bftest WHERE hasAny(x, [1,2,k]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:663: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000001b450232 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b2441 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001c4b4e98 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b8ec 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:13:36.337988 [ 1855 ] {} TCPHandler: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:663: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000001b450232 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b2441 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001c4b4e98 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b8ec 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:13:36.357829 [ 1855 ] {424ba7aa-9453-4c25-baf8-591e4ec38eff} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37032) (comment: 01888_bloom_filter_hasAny.sql) (query 14, line 30) (in query: -- NULLs are not Ok SELECT count() FROM bftest WHERE hasAny(x, [NULL,-42]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:663: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000001b450232 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b2441 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001c4b4e98 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b8ec 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:13:36.358931 [ 1855 ] {} TCPHandler: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:663: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000001b450232 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b2441 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001c4b4e98 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b8ec 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:13:36.373819 [ 1855 ] {0b7a4df5-0a66-4c56-b5b9-688cbfc044c6} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37032) (comment: 01888_bloom_filter_hasAny.sql) (query 15, line 32) (in query: SELECT count() FROM bftest WHERE hasAny(x, [0,NULL]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:663: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000001b450232 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b2441 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001c4b4e98 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b8ec 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:13:36.374879 [ 1855 ] {} TCPHandler: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:663: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000001b450232 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b2441 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001c4b4e98 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b8ec 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:13:36.396985 [ 1855 ] {24682c8a-872c-4f40-a685-91ce322f25f2} executeQuery: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37032) (comment: 01888_bloom_filter_hasAny.sql) (query 16, line 34) (in query: -- non-compatible types SELECT count() FROM bftest WHERE hasAny(x, [[123], -42]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dfec5c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000174fb740 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000175001b3 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x00000000174c0d12 7. auto DB::Field::dispatch, DB::Field&>(DB::FieldToDataType<(DB::LeastSupertypeOnError)0>&&, DB::Field&) @ 0x000000000ac9a421 8. ./src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000017969e07 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x0000000017a5a341 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a44528 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a44efa 12. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:364: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a4a5cd 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a425e4 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a46116 15. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a424f6 16. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000017a4218a 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b0e7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:13:36.400285 [ 1855 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dfec5c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000174fb740 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000175001b3 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:170: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x00000000174c0d12 7. auto DB::Field::dispatch, DB::Field&>(DB::FieldToDataType<(DB::LeastSupertypeOnError)0>&&, DB::Field&) @ 0x000000000ac9a421 8. ./src/Common/FieldVisitors.h:24: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000017969e07 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Field const&, 0>(std::allocator const&, DB::Field const&) @ 0x0000000017a5a341 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a44528 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:701: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a44efa 12. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:364: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a4a5cd 13. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a425e4 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a46116 15. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000017a424f6 16. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000017a4218a 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b0e7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:13:36.425414 [ 1855 ] {469e328a-4493-4fd3-8651-b971b86c7d87} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37032) (comment: 01888_bloom_filter_hasAny.sql) (query 17, line 36) (in query: SELECT count() FROM bftest WHERE hasAny(x, [toDecimal32(123, 3), 2]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:663: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000001b450232 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b2441 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001c4b4e98 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b8ec 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:13:36.431175 [ 1855 ] {} TCPHandler: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:663: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000001b450232 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b2441 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:612: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001c4b4e98 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b8ec 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:13:39.336406 [ 2070 ] {cf0f1262-a9b1-4dcc-b4c8-82449ddfcc23} executeQuery: Code: 507. DB::Exception: Sharding key sub_key is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47634) (comment: 01319_optimize_skip_unused_shards_nesting.sql) (query 11, line 19) (in query: select * from dist_01319 where key = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001aa80a89 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001aa7f201 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa413 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000001897c75b 11. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:49: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x000000001c306ced 12. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:169: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x000000001a2b62ae 13. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:244: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x000000001a2b4196 14. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:321: DB::ClusterProxy::SelectStreamFactory::createForShard(DB::Cluster::ShardInfo const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>) @ 0x000000001a2b6749 15. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:369: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>, bool) @ 0x000000001a2a0f83 16. ./build_docker/./src/Storages/StorageDistributed.cpp:912: DB::StorageDistributed::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001aa853bd 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa683 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 19. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 20. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:13:39.345282 [ 2070 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key sub_key is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001aa80a89 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001aa7f201 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa413 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000001897c75b 11. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:49: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x000000001c306ced 12. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:169: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x000000001a2b62ae 13. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:244: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x000000001a2b4196 14. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:321: DB::ClusterProxy::SelectStreamFactory::createForShard(DB::Cluster::ShardInfo const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>) @ 0x000000001a2b6749 15. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:369: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>, bool) @ 0x000000001a2a0f83 16. ./build_docker/./src/Storages/StorageDistributed.cpp:912: DB::StorageDistributed::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001aa853bd 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa683 18. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 19. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 20. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:13:46.187572 [ 419 ] {ad59f6fc-e735-4fa9-b86f-498774b3d50b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_decrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 1, line 4) (in query: --- aes_decrypt_mysql(string, key, block_mode[, init_vector, AAD]) -- The MySQL-compatitable encryption, only ecb, cbc and ofb modes are supported, -- just like for MySQL -- https://dev.mysql.com/doc/refman/8.0/en/encryption-functions.html#function_aes-encrypt -- https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_block_encryption_mode -- Please note that for keys that exceed mode-specific length, keys are folded in a MySQL-specific way, -- meaning that whole key is used, but effective key length is still determined by mode. -- when key doesn't exceed the default mode length, ecryption result equals with AES_encypt() ----------------------------------------------------------------------------------------- -- error cases ----------------------------------------------------------------------------------------- SELECT aes_decrypt_mysql();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096765b2 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:13:46.192750 [ 419 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_decrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096765b2 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:13:46.242857 [ 419 ] {0273f00b-755c-45f8-9734-ef380191e0e7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_decrypt_mysql('aes-128-ecb'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 2, line 17) (in query: SELECT aes_decrypt_mysql('aes-128-ecb');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096765b2 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:13:46.252883 [ 419 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_decrypt_mysql('aes-128-ecb'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096765b2 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:13:46.348979 [ 419 ] {9319e121-2f75-40ac-b060-3c213845d939} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 3, line 18) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096765b2 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:13:46.350487 [ 419 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096765b2 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:13:46.654535 [ 419 ] {2732cf27-5c9f-4568-959c-b21f2456f37e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_decrypt_mysql'. Expected: decryption mode string, got: UInt16: In scope SELECT aes_decrypt_mysql(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 4, line 20) (in query: SELECT aes_decrypt_mysql(789, '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096765b2 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:46.661040 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_decrypt_mysql'. Expected: decryption mode string, got: UInt16: In scope SELECT aes_decrypt_mysql(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096765b2 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:46.813890 [ 419 ] {2cf5bae3-72cb-4c27-ac19-78daba3be8f3} executeQuery: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT aes_decrypt_mysql('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 5, line 22) (in query: SELECT aes_decrypt_mysql('blah blah blah', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096760b7 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:13:46.817548 [ 419 ] {} TCPHandler: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT aes_decrypt_mysql('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096760b7 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:13:46.832604 [ 419 ] {1d232604-e860-4bfd-9e94-3b9e3d9a9bb6} executeQuery: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT aes_decrypt_mysql('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 6, line 23) (in query: SELECT aes_decrypt_mysql('des-ede3-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096760b7 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:13:46.836857 [ 419 ] {} TCPHandler: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT aes_decrypt_mysql('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096760b7 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:13:46.994506 [ 419 ] {e59386b5-c91c-404e-9874-d7ea7baa2a78} executeQuery: Code: 36. DB::Exception: Unsupported cipher mode: In scope SELECT aes_decrypt_mysql('aes-128-gcm', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 7, line 24) (in query: SELECT aes_decrypt_mysql('aes-128-gcm', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096761d1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:13:46.999379 [ 419 ] {} TCPHandler: Code: 36. DB::Exception: Unsupported cipher mode: In scope SELECT aes_decrypt_mysql('aes-128-gcm', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000096761d1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:13:47.136589 [ 419 ] {23113c0b-8449-44b0-bc02-6230fa75c599} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'decrypt'. Expected: decryption mode string, got: UInt16: In scope SELECT decrypt(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 8, line 26) (in query: SELECT decrypt(789, '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1feb39 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:47.138344 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'decrypt'. Expected: decryption mode string, got: UInt16: In scope SELECT decrypt(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1feb39 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:47.273570 [ 419 ] {e419a870-4c77-4c06-8860-773f75915599} executeQuery: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT decrypt('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 9, line 27) (in query: SELECT decrypt('blah blah blah', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe4bd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:13:47.276091 [ 419 ] {} TCPHandler: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT decrypt('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe4bd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:13:47.289056 [ 419 ] {3a5e86f1-c411-4d35-ab4f-e90e82ee0c3b} executeQuery: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT decrypt('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 10, line 28) (in query: SELECT decrypt('des-ede3-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe4bd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:13:47.290188 [ 419 ] {} TCPHandler: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT decrypt('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe4bd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:13:47.303020 [ 419 ] {9eb9320c-53e4-45f6-b253-0d38c1f6b4c6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'aes_decrypt_mysql'. Expected: decryption key binary string, got: UInt16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 11, line 31) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096765b2 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:47.307438 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'aes_decrypt_mysql'. Expected: decryption key binary string, got: UInt16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096765b2 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:49.598462 [ 419 ] {86d564e5-b106-4d7b-9072-3e886d8bd64a} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 12, line 33) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000009677026 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x0000000009676d02 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009675e8d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:13:49.599715 [ 419 ] {} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000009677026 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x0000000009676d02 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009675e8d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:13:51.132548 [ 419 ] {30ea4ccc-c4cd-408a-acf2-9cd30f1a28f8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 13, line 35) (in query: SELECT decrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1feb39 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:13:51.135482 [ 419 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1feb39 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:13:51.149100 [ 419 ] {442aba8e-2401-4024-99a6-b0c022060e73} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'decrypt'. Expected: decryption key binary string, got: UInt16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 14, line 36) (in query: SELECT decrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1feb39 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:51.155747 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'decrypt'. Expected: decryption key binary string, got: UInt16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1feb39 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:51.285547 [ 419 ] {cd0c7506-2cb9-45e6-85e3-405966fd267a} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 15, line 37) (in query: SELECT decrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000009677026 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000a1ffae7 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe266 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:13:51.291141 [ 419 ] {} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000009677026 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000a1ffae7 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe266 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:13:51.299447 [ 419 ] {35fc737e-c680-4eb6-a158-b12163d525ff} executeQuery: Code: 36. DB::Exception: Invalid key size: 36 expected 16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 16, line 38) (in query: SELECT decrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000009677026 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000a1ffae7 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe266 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:13:51.301138 [ 419 ] {} TCPHandler: Code: 36. DB::Exception: Invalid key size: 36 expected 16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000009677026 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000a1ffae7 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe266 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:13:51.445495 [ 419 ] {4b2c765c-e14b-432d-bea6-68574a654aa9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'aes_decrypt_mysql'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 17, line 40) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f35a 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096765b2 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:51.463564 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'aes_decrypt_mysql'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f35a 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096765b2 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:51.604815 [ 419 ] {9a623ecf-ed87-475f-bdb0-0bdc94d45386} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 18, line 42) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000009677026 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x0000000009676d02 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009675f46 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:13:51.620476 [ 419 ] {} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000009677026 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x0000000009676d02 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009675f46 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:13:51.774665 [ 419 ] {3a1057ce-4433-4c1c-8742-4212b975caf3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'decrypt'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 19, line 44) (in query: SELECT decrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f35a 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1feb39 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:51.778292 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'decrypt'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f35a 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1feb39 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:51.937764 [ 419 ] {91b066f5-f1fb-4a5f-95f6-6f623d94a59c} executeQuery: Code: 36. DB::Exception: Invalid IV size: 42 expected 16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 20, line 45) (in query: SELECT decrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000009677426 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000a1ffc66 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe32b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:13:51.939068 [ 419 ] {} TCPHandler: Code: 36. DB::Exception: Invalid IV size: 42 expected 16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000009677426 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000a1ffc66 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe32b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:13:51.948323 [ 419 ] {10005419-4153-4f35-80b6-4d6ef3bcb3ff} executeQuery: Code: 36. DB::Exception: Invalid IV size: 2 expected 16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 21, line 46) (in query: SELECT decrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000009677426 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000a1ffc66 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe32b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:13:51.958153 [ 419 ] {} TCPHandler: Code: 36. DB::Exception: Invalid IV size: 2 expected 16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000009677426 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000a1ffc66 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe32b 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:13:51.970902 [ 419 ] {05c858cb-dd38-44ff-8406-5fef0d7bf214} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 5 arguments: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 22, line 48) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096765b2 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:13:51.985023 [ 419 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 5 arguments: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000096765b2 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:13:51.997347 [ 419 ] {f9194f14-f23d-4fb2-85d1-65e15570cb8e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'decrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 23, line 51) (in query: SELECT decrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f35a 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1feb39 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:52.011635 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'decrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f35a 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1feb39 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:52.020310 [ 419 ] {ee621f8d-2086-4283-8118-805a96526935} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'decrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT decrypt('aes-128-gcm', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 24, line 52) (in query: SELECT decrypt('aes-128-gcm', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f35a 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1feb39 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:52.023898 [ 419 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'decrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT decrypt('aes-128-gcm', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f35a 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1feb39 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:13:52.133439 [ 16822 ] {c94f67db-8b1a-4e9e-b2cb-ea21250caefe} executeQuery: Code: 36. DB::Exception: Disk `s3_disk` already exists and is described by the config. It is impossible to redefine it.: While processing disk(name = 's3_disk', type = cache, max_size = '100Ki', path = `02808_custom_disk_with_user_defined_name_test_f392y3mj`, disk = s3_disk). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:44504) (comment: 02808_custom_disk_with_user_defined_name.sh) (query 2, line 3) (in query: CREATE TABLE test (`a` Int32, `b` String) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(name = 's3_disk', type = cache, max_size = '100Ki', path = `02808_custom_disk_with_user_defined_name_test_f392y3mj`, disk = s3_disk), index_granularity = 31169, min_bytes_for_wide_part = 902557121, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 113894495, compact_parts_max_granules_to_buffer = 140, compact_parts_merge_max_bytes_to_prefetch_part = 33512805, merge_max_block_size = 21329, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 623157, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 29552723, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 14982, primary_key_compress_block_size = 72813, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Disks/DiskFromAST.cpp:65: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x000000001b5f510b 5. ./build_docker/./src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x000000001b5f62dc 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001b5f602d 7. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001b5f5639 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x000000001b5969d7 9. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x000000001b59adb0 10. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7a8b67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:13:52.152158 [ 16822 ] {} TCPHandler: Code: 36. DB::Exception: Disk `s3_disk` already exists and is described by the config. It is impossible to redefine it.: While processing disk(name = 's3_disk', type = cache, max_size = '100Ki', path = `02808_custom_disk_with_user_defined_name_test_f392y3mj`, disk = s3_disk). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Disks/DiskFromAST.cpp:65: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x000000001b5f510b 5. ./build_docker/./src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x000000001b5f62dc 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001b5f602d 7. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001b5f5639 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x000000001b5969d7 9. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x000000001b59adb0 10. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7a8b67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:13:52.199847 [ 419 ] {d2e126c1-372a-422a-9936-2778907e52da} executeQuery: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 478150763: In scope SELECT ignore(decrypt('aes-128-ecb', '[HIDDEN]')). (OPENSSL_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 25, line 54) (in query: SELECT ignore(decrypt('aes-128-ecb', '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long&&) @ 0x000000000881b406 4. DB::OpenSSLDetails::onError(String) @ 0x000000000881b1d6 5. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000a1ffc00 6. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe266 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:13:52.213812 [ 419 ] {} TCPHandler: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 478150763: In scope SELECT ignore(decrypt('aes-128-ecb', '[HIDDEN]')). (OPENSSL_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long&&) @ 0x000000000881b406 4. DB::OpenSSLDetails::onError(String) @ 0x000000000881b1d6 5. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000a1ffc00 6. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe266 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:13:52.247803 [ 419 ] {2cb4cb33-4dd6-4f0d-9e9b-f6a7b0c32884} executeQuery: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 478150763: In scope SELECT ignore(decrypt('aes-128-cbc', '[HIDDEN]')). (OPENSSL_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 26, line 56) (in query: SELECT ignore(decrypt('aes-128-cbc', '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long&&) @ 0x000000000881b406 4. DB::OpenSSLDetails::onError(String) @ 0x000000000881b1d6 5. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000a1ffc00 6. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe266 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:13:52.251377 [ 419 ] {} TCPHandler: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 478150763: In scope SELECT ignore(decrypt('aes-128-cbc', '[HIDDEN]')). (OPENSSL_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long&&) @ 0x000000000881b406 4. DB::OpenSSLDetails::onError(String) @ 0x000000000881b1d6 5. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000a1ffc00 6. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe266 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:13:52.708091 [ 16819 ] {c126e6b2-f564-48da-9dd2-8cc8408e7e08} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT IPv4StringToNum('test'). (CANNOT_PARSE_IPV4) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:44532) (comment: 02234_cast_to_ip_address.sql) (query 2, line 3) (in query: SELECT IPv4StringToNum('test');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000088cd8ae 5. DB::FunctionIPv4StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cbdb2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:13:52.711115 [ 16819 ] {} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT IPv4StringToNum('test'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000088cd8ae 5. DB::FunctionIPv4StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088cbdb2 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:13:54.525500 [ 2054 ] {5c91cf0f-fedd-4cf3-b9a7-988301425b71} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 100.24 MiB (attempt to allocate chunk of 1.02 MiB bytes), maximum: 100.00 MiB.: while receiving packet from 127.6:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37010) (comment: 01730_distributed_group_by_no_merge_order_by_long.sql) (query 3, line 6) (in query: -- does not use 127.1 due to prefer_localhost_replica select * from remote('127.{2..11}', view(select * from numbers(1e6))) group by number order by number limit 20 settings distributed_group_by_no_merge=0, max_memory_usage='100Mi';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000010ae113a 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000087e55f5 10. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x00000000175a1d3d 11. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000017511b46 12. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000001bcaf7c9 13. ./build_docker/./src/Client/Connection.cpp:1363: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000001ba377ca 14. ./build_docker/./src/Client/Connection.cpp:1344: DB::Connection::receivePacket() @ 0x000000001ba35fb1 15. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001ba9d11e 16. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 17. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 18. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 2025.07.28 06:13:54.607245 [ 16819 ] {98e578ff-0993-4281-86c7-3551d1bc646b} executeQuery: Code: 675. DB::Exception: Cannot parse IPv4 test: Cannot parse IPv4 from String: In scope SELECT toIPv4('test'). (CANNOT_PARSE_IPV4) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:44532) (comment: 02234_cast_to_ip_address.sql) (query 9, line 13) (in query: SELECT toIPv4('test');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000088dac80 4. ./src/IO/ReadHelpers.h:971: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000001633c6ec 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000016336dd4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161e25af 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620b547 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620aa60 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:13:54.614270 [ 16819 ] {} TCPHandler: Code: 675. DB::Exception: Cannot parse IPv4 test: Cannot parse IPv4 from String: In scope SELECT toIPv4('test'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000088dac80 4. ./src/IO/ReadHelpers.h:971: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000001633c6ec 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000016336dd4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161e25af 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620b547 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620aa60 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:13:54.739473 [ 419 ] {9fb5c06a-130c-462d-8296-5e9173ce0552} executeQuery: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 0: while executing 'FUNCTION and(greater(__table1.user_id, 0_UInt8) :: 7, equals(decrypt('aes-256-gcm'_String, __table1.encrypted, 'keykeykeykeykeykeykeykeykeykey02'_String, __table1.iv), 'value2'_String) :: 2) -> and(greater(__table1.user_id, 0_UInt8), equals(decrypt('aes-256-gcm'_String, __table1.encrypted, 'keykeykeykeykeykeykeykeykeykey02'_String, __table1.iv), 'value2'_String)) UInt8 : 6'. (OPENSSL_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47662) (comment: 01318_decrypt.sql) (query 66, line 142) (in query: SELECT dt, user_id FROM decrypt_null WHERE (user_id > 0) AND (decrypt('aes-256-gcm', '[HIDDEN]') = 'value2')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long&&) @ 0x000000000881b406 4. DB::OpenSSLDetails::onError(String) @ 0x000000000881b1d6 5. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000a1ffe1a 6. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe32b 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 12. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x000000001a4b5e02 13. ./build_docker/./src/Columns/ColumnFunction.cpp:361: DB::ColumnFunction::reduce() const @ 0x000000001a4b5ad6 14. ./build_docker/./src/Columns/MaskOperations.cpp:285: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000001a9c26b6 15. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::executeShortCircuit(std::vector>&, std::shared_ptr const&) const @ 0x0000000015f8d5f5 16. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f87e30 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 22. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 23. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 24. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 25. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 2025.07.28 06:13:54.742245 [ 419 ] {} TCPHandler: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 0: while executing 'FUNCTION and(greater(__table1.user_id, 0_UInt8) :: 7, equals(decrypt('aes-256-gcm'_String, __table1.encrypted, 'keykeykeykeykeykeykeykeykeykey02'_String, __table1.iv), 'value2'_String) :: 2) -> and(greater(__table1.user_id, 0_UInt8), equals(decrypt('aes-256-gcm'_String, __table1.encrypted, 'keykeykeykeykeykeykeykeykeykey02'_String, __table1.iv), 'value2'_String)) UInt8 : 6'. (OPENSSL_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long&&) @ 0x000000000881b406 4. DB::OpenSSLDetails::onError(String) @ 0x000000000881b1d6 5. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000a1ffe1a 6. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1fe32b 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 12. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x000000001a4b5e02 13. ./build_docker/./src/Columns/ColumnFunction.cpp:361: DB::ColumnFunction::reduce() const @ 0x000000001a4b5ad6 14. ./build_docker/./src/Columns/MaskOperations.cpp:285: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x000000001a9c26b6 15. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::executeShortCircuit(std::vector>&, std::shared_ptr const&) const @ 0x0000000015f8d5f5 16. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f87e30 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 22. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 23. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 24. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 25. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:13:54.766747 [ 1861 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46290, local: [::ffff:127.0.0.11]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:54.766959 [ 1808 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:50934, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:54.767150 [ 1861 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46290, local: [::ffff:127.0.0.11]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:54.767322 [ 2064 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:40624, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:54.767665 [ 2064 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:40624, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:54.766770 [ 1851 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46812, local: [::ffff:127.0.0.8]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:54.768605 [ 1867 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51328, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:54.768898 [ 1808 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:50934, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:54.769360 [ 6818 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:34750, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:54.769500 [ 1867 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51328, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:54.769716 [ 1851 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46812, local: [::ffff:127.0.0.8]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:54.770200 [ 6818 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:34750, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:13:54.873176 [ 2054 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 100.24 MiB (attempt to allocate chunk of 1.02 MiB bytes), maximum: 100.00 MiB.: while receiving packet from 127.6:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000010ae113a 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x00000000087e55f5 10. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x00000000175a1d3d 11. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000017511b46 12. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000001bcaf7c9 13. ./build_docker/./src/Client/Connection.cpp:1363: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000001ba377ca 14. ./build_docker/./src/Client/Connection.cpp:1344: DB::Connection::receivePacket() @ 0x000000001ba35fb1 15. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001ba9d11e 16. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 17. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 18. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd113db 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:13:55.003385 [ 16819 ] {301e100a-6e15-42d6-9761-b5096bb92ba2} executeQuery: Code: 70. DB::Exception: IPv6 ::afff:102:304 in column IPv6 is not in IPv4 mapping block: In scope SELECT toIPv4(toIPv6('::afff:1.2.3.4')). (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:44532) (comment: 02234_cast_to_ip_address.sql) (query 17, line 24) (in query: SELECT toIPv4(toIPv6('::afff:1.2.3.4'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char (&) [46], String&&) @ 0x0000000015ffac26 4. ./src/Functions/FunctionsConversion.h:1779: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001633f9e7 5. ./src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161e2c3a 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620b547 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620aa60 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:13:55.005477 [ 16819 ] {} TCPHandler: Code: 70. DB::Exception: IPv6 ::afff:102:304 in column IPv6 is not in IPv4 mapping block: In scope SELECT toIPv4(toIPv6('::afff:1.2.3.4')). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char (&) [46], String&&) @ 0x0000000015ffac26 4. ./src/Functions/FunctionsConversion.h:1779: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001633f9e7 5. ./src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161e2c3a 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620b547 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620aa60 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:13:55.233532 [ 16819 ] {12cd47f9-3a05-4b38-a695-4c57715c4682} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT CAST('test', 'IPv4'). (CANNOT_PARSE_IPV4) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:44532) (comment: 02234_cast_to_ip_address.sql) (query 21, line 30) (in query: SELECT cast('test' , 'IPv4');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000015fef32e 5. bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000015fed800 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015fed602 7. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:13:55.234673 [ 16819 ] {} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT CAST('test', 'IPv4'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000015fef32e 5. bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000015fed800 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015fed602 7. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:13:55.272177 [ 2095 ] {68afda2e-1e4c-4af9-89af-895d6905886b} executeQuery: Code: 48. DB::Exception: EXPLAIN QUERY TREE is only supported with a new analyzer. Set allow_experimental_analyzer = 1. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:44602) (comment: 02703_explain_query_tree_is_forbidden_with_old_analyzer.sql) (query 2, line 2) (in query: EXPLAIN QUERY TREE run_passes = true, dump_passes = true SELECT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:438: DB::InterpreterExplainQuery::executeImpl() @ 0x00000000188faf36 5. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x00000000188f5adf 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:13:55.273686 [ 2095 ] {} TCPHandler: Code: 48. DB::Exception: EXPLAIN QUERY TREE is only supported with a new analyzer. Set allow_experimental_analyzer = 1. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:438: DB::InterpreterExplainQuery::executeImpl() @ 0x00000000188faf36 5. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x00000000188f5adf 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:13:55.716934 [ 16819 ] {c5bdad78-b6a7-4e69-9797-80bce1cbc006} executeQuery: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT IPv6StringToNum('test'). (CANNOT_PARSE_IPV6) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:44532) (comment: 02234_cast_to_ip_address.sql) (query 33, line 48) (in query: SELECT IPv6StringToNum('test');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000088d5093 5. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000088d2e39 6. DB::FunctionIPv6StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088d2392 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:13:55.719232 [ 16819 ] {} TCPHandler: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT IPv6StringToNum('test'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000088d5093 5. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000088d2e39 6. DB::FunctionIPv6StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088d2392 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:13:56.166290 [ 16819 ] {5cc51338-ff83-4262-96b3-fd5f58ea3df5} executeQuery: Code: 676. DB::Exception: Cannot parse IPv6 test: Cannot parse IPv6 from String: In scope SELECT toIPv6('test'). (CANNOT_PARSE_IPV6) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:44532) (comment: 02234_cast_to_ip_address.sql) (query 40, line 58) (in query: SELECT toIPv6('test');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000088dac80 4. ./src/IO/ReadHelpers.h:993: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000163454e8 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000016340154 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161e3aaf 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620cfe7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620c500 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:13:56.171742 [ 16819 ] {} TCPHandler: Code: 676. DB::Exception: Cannot parse IPv6 test: Cannot parse IPv6 from String: In scope SELECT toIPv6('test'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000088dac80 4. ./src/IO/ReadHelpers.h:993: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000163454e8 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000016340154 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161e3aaf 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620cfe7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620c500 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:13:56.339508 [ 16819 ] {cf57b712-5ad3-4d7f-8d2c-0ed531d85c53} executeQuery: Code: 676. DB::Exception: Cannot parse IPv6 .1.2.3: Cannot parse IPv6 from String: In scope SELECT toIPv6('::.1.2.3'). (CANNOT_PARSE_IPV6) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:44532) (comment: 02234_cast_to_ip_address.sql) (query 46, line 66) (in query: SELECT toIPv6('::.1.2.3');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000088dac80 4. ./src/IO/ReadHelpers.h:993: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000163454e8 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000016340154 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161e3aaf 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620cfe7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620c500 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:13:56.340932 [ 16819 ] {} TCPHandler: Code: 676. DB::Exception: Cannot parse IPv6 .1.2.3: Cannot parse IPv6 from String: In scope SELECT toIPv6('::.1.2.3'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000088dac80 4. ./src/IO/ReadHelpers.h:993: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000163454e8 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x0000000016340154 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161e3aaf 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620cfe7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001620c500 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:13:56.984491 [ 1867 ] {f9c9fa6c-6302-429b-851f-a961c233c66e} executeQuery: Code: 36. DB::Exception: Unsupported aggregate function count, supported functions are any,anyLast,min,max,sum,sumWithOverflow,groupBitAnd,groupBitOr,groupBitXor,sumMap,minMap,maxMap,groupArrayArray,groupArrayLastArray,groupUniqArrayArray,groupUniqArrayArrayMap,sumMappedArrays,minMappedArrays,maxMappedArrays. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:44670) (comment: 01570_aggregator_combinator_simple_state.sql) (query 15, line 17) (in query: -- non-SimpleAggregateFunction with countSimpleState(number) as c select toTypeName(c), c from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/DataTypes/DataTypeCustomSimpleAggregateFunction.cpp:59: DB::DataTypeCustomSimpleAggregateFunction::checkSupportedFunctions(std::shared_ptr const&) @ 0x00000000174190d7 5. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:32: DB::AggregateFunctionSimpleState::createResultType(std::shared_ptr const&, DB::Array const&) @ 0x0000000013c580cb 6. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:23: DB::AggregateFunctionSimpleState::AggregateFunctionSimpleState(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000013c57f49 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000013c870a4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorSimpleState::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c86f8e 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9807c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99118 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:13:56.989411 [ 1867 ] {} TCPHandler: Code: 36. DB::Exception: Unsupported aggregate function count, supported functions are any,anyLast,min,max,sum,sumWithOverflow,groupBitAnd,groupBitOr,groupBitXor,sumMap,minMap,maxMap,groupArrayArray,groupArrayLastArray,groupUniqArrayArray,groupUniqArrayArrayMap,sumMappedArrays,minMappedArrays,maxMappedArrays. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/DataTypes/DataTypeCustomSimpleAggregateFunction.cpp:59: DB::DataTypeCustomSimpleAggregateFunction::checkSupportedFunctions(std::shared_ptr const&) @ 0x00000000174190d7 5. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:32: DB::AggregateFunctionSimpleState::createResultType(std::shared_ptr const&, DB::Array const&) @ 0x0000000013c580cb 6. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:23: DB::AggregateFunctionSimpleState::AggregateFunctionSimpleState(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000013c57f49 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000013c870a4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorSimpleState::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c86f8e 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9807c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99118 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:14:02.384851 [ 17043 ] {e14d95cf-6816-4997-a73d-4b4693d43dff} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 40.63 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54082) (comment: 01730_distributed_group_by_no_merge_order_by_long.sql) (query 5, line 12) (in query: SELECT `__table1`.`number` AS `number` FROM view(SELECT * FROM numbers(1000000.)) AS `__table1` GROUP BY `__table1`.`number` ORDER BY `__table1`.`number` ASC LIMIT _CAST(1000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000010ae1d5a 9. ./src/Common/HashTable/HashTable.h:491: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::alloc(HashTableGrowerWithPrecalculation<8ul> const&) @ 0x000000001881c67e 10. ./src/Common/HashTable/HashTable.h:719: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000001880ea16 11. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:67: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x0000000018803cf2 12. ./build_docker/./src/Interpreters/Aggregator.cpp:122: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x00000000183b28ea 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1514: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b894f 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:14:02.384900 [ 1860 ] {d79ec175-5153-4a6c-a7f0-42b27124c4eb} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 40.63 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48036) (comment: 01730_distributed_group_by_no_merge_order_by_long.sql) (query 5, line 12) (in query: SELECT `__table1`.`number` AS `number` FROM view(SELECT * FROM numbers(1000000.)) AS `__table1` GROUP BY `__table1`.`number` ORDER BY `__table1`.`number` ASC LIMIT _CAST(1000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000010ae1d5a 9. ./src/Common/HashTable/HashTable.h:491: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::alloc(HashTableGrowerWithPrecalculation<8ul> const&) @ 0x000000001881c67e 10. ./src/Common/HashTable/HashTable.h:719: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000001880ea16 11. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:67: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x0000000018803cf2 12. ./build_docker/./src/Interpreters/Aggregator.cpp:122: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x00000000183b28ea 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1514: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b894f 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:14:02.388160 [ 16822 ] {e2d9357f-0dc6-4a37-bd1e-e7d5d959dd7d} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 40.63 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35932) (comment: 01730_distributed_group_by_no_merge_order_by_long.sql) (query 5, line 12) (in query: SELECT `__table1`.`number` AS `number` FROM view(SELECT * FROM numbers(1000000.)) AS `__table1` GROUP BY `__table1`.`number` ORDER BY `__table1`.`number` ASC LIMIT _CAST(1000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000010ae1d5a 9. ./src/Common/HashTable/HashTable.h:491: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::alloc(HashTableGrowerWithPrecalculation<8ul> const&) @ 0x000000001881c67e 10. ./src/Common/HashTable/HashTable.h:719: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000001880ea16 11. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:67: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x0000000018803cf2 12. ./build_docker/./src/Interpreters/Aggregator.cpp:122: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x00000000183b28ea 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1514: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b894f 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:14:02.388202 [ 2064 ] {11424869-9a0f-48a7-b6ff-1fbbb68d9f1a} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 40.63 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:36494) (comment: 01730_distributed_group_by_no_merge_order_by_long.sql) (query 5, line 12) (in query: SELECT `__table1`.`number` AS `number` FROM view(SELECT * FROM numbers(1000000.)) AS `__table1` GROUP BY `__table1`.`number` ORDER BY `__table1`.`number` ASC LIMIT _CAST(1000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000010ae1d5a 9. ./src/Common/HashTable/HashTable.h:491: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::alloc(HashTableGrowerWithPrecalculation<8ul> const&) @ 0x000000001881c67e 10. ./src/Common/HashTable/HashTable.h:719: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000001880ea16 11. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:67: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x0000000018803cf2 12. ./build_docker/./src/Interpreters/Aggregator.cpp:122: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x00000000183b28ea 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1514: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b894f 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:14:02.388292 [ 2062 ] {eb6a8503-e63c-476c-9cc5-71ce79764ad6} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 40.63 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:46374) (comment: 01730_distributed_group_by_no_merge_order_by_long.sql) (query 5, line 12) (in query: SELECT `__table1`.`number` AS `number` FROM view(SELECT * FROM numbers(1000000.)) AS `__table1` GROUP BY `__table1`.`number` ORDER BY `__table1`.`number` ASC LIMIT _CAST(1000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000010ae1d5a 9. ./src/Common/HashTable/HashTable.h:491: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::alloc(HashTableGrowerWithPrecalculation<8ul> const&) @ 0x000000001881c67e 10. ./src/Common/HashTable/HashTable.h:719: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000001880ea16 11. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:67: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x0000000018803cf2 12. ./build_docker/./src/Interpreters/Aggregator.cpp:122: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x00000000183b28ea 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1514: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b894f 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:14:02.392369 [ 2054 ] {0de0e9e6-5417-40bb-83bb-42525c0fa564} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 21.39 MiB (attempt to allocate chunk of 1.63 MiB bytes), maximum: 20.00 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37010) (comment: 01730_distributed_group_by_no_merge_order_by_long.sql) (query 5, line 12) (in query: -- since the MergingSortedTransform will start processing only when all ports (remotes) will have some data, -- and the query with GROUP BY on remote servers will first do GROUP BY and then send the block, -- so the initiator will first receive all blocks from remotes and only after start merging, -- and will hit the memory limit. select * from remote('127.{2..11}', view(select * from numbers(1e6))) group by number order by number limit 1e6 settings distributed_group_by_no_merge=2, max_memory_usage='20Mi', max_block_size=4294967296;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000010ae113a 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000010c2d326 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x0000000010d8614a 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x0000000010d8642e 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001ba3fe7e 13. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000001ba3fe09 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000001ba2157c 15. ./build_docker/./src/Client/Connection.cpp:660: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000001ba2ad6d 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:60: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000001ba4a5be 17. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000001ba4cb2f 18. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 19. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 20. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 2025.07.28 06:14:02.394142 [ 1860 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 40.63 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000010ae1d5a 9. ./src/Common/HashTable/HashTable.h:491: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::alloc(HashTableGrowerWithPrecalculation<8ul> const&) @ 0x000000001881c67e 10. ./src/Common/HashTable/HashTable.h:719: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000001880ea16 11. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:67: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x0000000018803cf2 12. ./build_docker/./src/Interpreters/Aggregator.cpp:122: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x00000000183b28ea 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1514: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b894f 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:14:02.394505 [ 17043 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 40.63 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000010ae1d5a 9. ./src/Common/HashTable/HashTable.h:491: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::alloc(HashTableGrowerWithPrecalculation<8ul> const&) @ 0x000000001881c67e 10. ./src/Common/HashTable/HashTable.h:719: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000001880ea16 11. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:67: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x0000000018803cf2 12. ./build_docker/./src/Interpreters/Aggregator.cpp:122: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x00000000183b28ea 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1514: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b894f 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:14:02.394850 [ 2062 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 40.63 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000010ae1d5a 9. ./src/Common/HashTable/HashTable.h:491: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::alloc(HashTableGrowerWithPrecalculation<8ul> const&) @ 0x000000001881c67e 10. ./src/Common/HashTable/HashTable.h:719: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000001880ea16 11. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:67: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x0000000018803cf2 12. ./build_docker/./src/Interpreters/Aggregator.cpp:122: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x00000000183b28ea 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1514: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b894f 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:14:02.395100 [ 16822 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 40.63 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000010ae1d5a 9. ./src/Common/HashTable/HashTable.h:491: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::alloc(HashTableGrowerWithPrecalculation<8ul> const&) @ 0x000000001881c67e 10. ./src/Common/HashTable/HashTable.h:719: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000001880ea16 11. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:67: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x0000000018803cf2 12. ./build_docker/./src/Interpreters/Aggregator.cpp:122: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x00000000183b28ea 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1514: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b894f 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:14:02.395653 [ 2064 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 40.63 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 20.00 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000010ae1d5a 9. ./src/Common/HashTable/HashTable.h:491: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::alloc(HashTableGrowerWithPrecalculation<8ul> const&) @ 0x000000001881c67e 10. ./src/Common/HashTable/HashTable.h:719: auto DB::constructWithReserveIfPossible, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(unsigned long) @ 0x000000001880ea16 11. ./build_docker/./src/Interpreters/AggregatedDataVariants.cpp:67: DB::AggregatedDataVariants::init(DB::AggregatedDataVariants::Type, std::optional) @ 0x0000000018803cf2 12. ./build_docker/./src/Interpreters/Aggregator.cpp:122: (anonymous namespace)::initDataVariantsWithSizeHint(DB::AggregatedDataVariants&, DB::AggregatedDataVariants::Type, DB::Aggregator::Params const&) @ 0x00000000183b28ea 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1514: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b894f 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:14:02.398882 [ 17043 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:54082, local: [::ffff:127.0.0.7]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:14:02.400672 [ 17043 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:54082, local: [::ffff:127.0.0.7]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:14:02.402598 [ 1860 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:48036, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:14:02.403007 [ 1860 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:48036, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:14:02.410181 [ 2062 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46374, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:14:02.410584 [ 2062 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46374, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:14:02.413315 [ 16822 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:35932, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:14:02.413647 [ 16822 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:35932, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:14:02.415932 [ 2064 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:36494, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:14:02.416298 [ 2064 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:36494, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:14:02.424992 [ 2054 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 21.39 MiB (attempt to allocate chunk of 1.63 MiB bytes), maximum: 20.00 MiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x0000000010ae113a 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x0000000010c2d326 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x0000000010d8614a 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x0000000010d8642e 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001ba3fe7e 13. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000001ba3fe09 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000001ba2157c 15. ./build_docker/./src/Client/Connection.cpp:660: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000001ba2ad6d 16. ./build_docker/./src/Client/ConnectionEstablisher.cpp:60: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000001ba4a5be 17. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000001ba4cb2f 18. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 19. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 20. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:14:02.542437 [ 1855 ] {ee56eef1-0c52-4160-bfa6-bc7458fc7f2b} executeQuery: Code: 36. DB::Exception: From array size and to array size mismatch: In scope SELECT bitmapTransform(arrayReduce('groupBitmapState', [1]), [1, 2], [1, 2, 3]). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53126) (comment: 02430_bitmap_transform_exception_code.sql) (query 1, line 1) (in query: SELECT bitmapTransform(arrayReduce('groupBitmapState', [1]), [1, 2], [1, 2, 3]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. COW::immutable_ptr DB::FunctionBitmapTransform::executeIntType(std::vector> const&, unsigned long) const @ 0x00000000088664a9 5. DB::FunctionBitmapTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008864f51 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:14:02.544420 [ 1855 ] {} TCPHandler: Code: 36. DB::Exception: From array size and to array size mismatch: In scope SELECT bitmapTransform(arrayReduce('groupBitmapState', [1]), [1, 2], [1, 2, 3]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. COW::immutable_ptr DB::FunctionBitmapTransform::executeIntType(std::vector> const&, unsigned long) const @ 0x00000000088664a9 5. DB::FunctionBitmapTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008864f51 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:14:27.308224 [ 1867 ] {085c94d8-9b10-4084-9a91-49566e56a8a9} executeQuery: Code: 69. DB::Exception: Negative scales and scales larger than precision are not supported. (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33786) (comment: 00700_decimal_bounds.sql) (query 2, line 3) (in query: CREATE TABLE IF NOT EXISTS decimal (x DECIMAL(10, -2)) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/DataTypes/DataTypeDecimalBase.h:177: std::shared_ptr DB::createDecimal(unsigned long, unsigned long) @ 0x00000000166efa8e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:95: DB::create(std::shared_ptr const&) @ 0x000000001748592e 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:14:27.314788 [ 1867 ] {} TCPHandler: Code: 69. DB::Exception: Negative scales and scales larger than precision are not supported. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/DataTypes/DataTypeDecimalBase.h:177: std::shared_ptr DB::createDecimal(unsigned long, unsigned long) @ 0x00000000166efa8e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:95: DB::create(std::shared_ptr const&) @ 0x000000001748592e 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:14:27.323118 [ 1867 ] {5e392fb7-1668-40b6-88c3-f8264c3a0db4} executeQuery: Code: 69. DB::Exception: Negative scales and scales larger than precision are not supported. (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33786) (comment: 00700_decimal_bounds.sql) (query 3, line 4) (in query: CREATE TABLE IF NOT EXISTS decimal (x DECIMAL(10, 15)) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/DataTypes/DataTypeDecimalBase.h:177: std::shared_ptr DB::createDecimal(unsigned long, unsigned long) @ 0x00000000166efa8e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:95: DB::create(std::shared_ptr const&) @ 0x000000001748592e 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:14:27.328169 [ 1867 ] {} TCPHandler: Code: 69. DB::Exception: Negative scales and scales larger than precision are not supported. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/DataTypes/DataTypeDecimalBase.h:177: std::shared_ptr DB::createDecimal(unsigned long, unsigned long) @ 0x00000000166efa8e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:95: DB::create(std::shared_ptr const&) @ 0x000000001748592e 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:14:27.471082 [ 1867 ] {cbc644b5-851d-4001-b695-57681c62f3d4} executeQuery: Code: 69. DB::Exception: Wrong precision: it must be between 1 and 76, got 0. (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33786) (comment: 00700_decimal_bounds.sql) (query 4, line 5) (in query: CREATE TABLE IF NOT EXISTS decimal (x DECIMAL(0, 0)) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&&, unsigned long&&, unsigned long&) @ 0x000000001671872c 4. ./src/DataTypes/DataTypeDecimalBase.h:173: std::shared_ptr DB::createDecimal(unsigned long, unsigned long) @ 0x00000000166efa1d 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:95: DB::create(std::shared_ptr const&) @ 0x000000001748592e 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:14:27.473190 [ 1867 ] {} TCPHandler: Code: 69. DB::Exception: Wrong precision: it must be between 1 and 76, got 0. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&&, unsigned long&&, unsigned long&) @ 0x000000001671872c 4. ./src/DataTypes/DataTypeDecimalBase.h:173: std::shared_ptr DB::createDecimal(unsigned long, unsigned long) @ 0x00000000166efa1d 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:95: DB::create(std::shared_ptr const&) @ 0x000000001748592e 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:78: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000001742dc01 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:569: DB::InterpreterCreateQuery::getColumnType(DB::ASTColumnDeclaration const&, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b43d6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:625: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4ba2 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:14:30.479154 [ 2070 ] {35c5161e-ca99-4845-b249-5cdc0ac3da7b} executeQuery: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37734) (comment: 02935_parallel_replicas_settings.sql) (query 7, line 9) (in query: SELECT count() FROM test_parallel_replicas_settings WHERE NOT ignore(*);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/Context.cpp:6297: DB::Context::getClusterForParallelReplicas() const @ 0x00000000181d189f 5. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:823: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x000000001a2a9f28 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1012: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa765 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:14:30.487201 [ 2070 ] {} TCPHandler: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/Context.cpp:6297: DB::Context::getClusterForParallelReplicas() const @ 0x00000000181d189f 5. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:823: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x000000001a2a9f28 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1012: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa765 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:14:33.619277 [ 2070 ] {2497ac12-a7c6-49f2-b749-0fa1855729ee} executeQueryWithParallelReplicas: Setting 'use_hedged_requests' explicitly with enabled 'enable_parallel_replicas' has no effect. Hedged connections are not used for parallel reading from replicas 2025.07.28 06:14:33.936978 [ 16822 ] {f5a4f980-f9fa-4e00-8950-53f341cde058} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 5 and result: 4). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37818) (comment: 00504_insert_miss_columns.sh) (query 1, line 1) (in query: INSERT INTO advertiser_test SELECT *, sipHash64( CAST(adblock AS String) ), CAST(1 AS Int8) FROM advertiser;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000009677026 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1547: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x00000000179dd52b 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000018918ac4 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:14:33.947068 [ 16822 ] {} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 5 and result: 4). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000009677026 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1547: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x00000000179dd52b 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000018918ac4 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:14:36.593996 [ 1851 ] {c1356fb5-429c-4579-8027-299923884ee7} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('stddevSampOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37912) (comment: 02996_nullable_arrayReduce.sql) (query 1, line 1) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/59600 SELECT arrayReduce(toNullable('stddevSampOrNull'), [1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x00000000103acdd9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:14:36.595125 [ 1851 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('stddevSampOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x00000000103acdd9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:14:36.605676 [ 1851 ] {d660aea2-b160-4bd5-9bc9-23f2c0f656b3} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('median'), [toDecimal32OrNull(toFixedString('1', 1), 2), 8]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37912) (comment: 02996_nullable_arrayReduce.sql) (query 2, line 3) (in query: SELECT arrayReduce(toNullable('median'), [toDecimal32OrNull(toFixedString('1', 1), 2), 8]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x00000000103acdd9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:14:36.607059 [ 1851 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('median'), [toDecimal32OrNull(toFixedString('1', 1), 2), 8]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x00000000103acdd9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:14:36.615167 [ 1851 ] {b5eb06aa-9862-4d5e-8735-380ec15d11e6} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT toFixedString('--- Int Empty ---', toLowCardinality(17)), arrayReduce(toNullable('avgOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37912) (comment: 02996_nullable_arrayReduce.sql) (query 3, line 4) (in query: SELECT toFixedString('--- Int Empty ---', toLowCardinality(17)), arrayReduce(toNullable('avgOrNull'), [1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x00000000103acdd9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:14:36.616117 [ 1851 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT toFixedString('--- Int Empty ---', toLowCardinality(17)), arrayReduce(toNullable('avgOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x00000000103acdd9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:14:36.774677 [ 1851 ] {8f650ed8-651e-41a1-a566-85d72839a646} executeQuery: Code: 43. DB::Exception: Argument 1 for function arrayReduce must be an array but it has type Nullable(UInt8).: In scope SELECT arrayReduce('any', toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37912) (comment: 02996_nullable_arrayReduce.sql) (query 4, line 5) (in query: SELECT arrayReduce('any', toNullable(3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000ec6672c 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x00000000103acf7f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:14:36.775901 [ 1851 ] {} TCPHandler: Code: 43. DB::Exception: Argument 1 for function arrayReduce must be an array but it has type Nullable(UInt8).: In scope SELECT arrayReduce('any', toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000ec6672c 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x00000000103acf7f 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:14:36.788045 [ 1851 ] {c531c55b-49a9-44b1-b456-98c2359ab1de} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toLowCardinality('median'), [toLowCardinality(toNullable(8))]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37912) (comment: 02996_nullable_arrayReduce.sql) (query 5, line 6) (in query: SELECT arrayReduce(toLowCardinality('median'), [toLowCardinality(toNullable(8))]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x00000000103acdd9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:14:36.789566 [ 1851 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toLowCardinality('median'), [toLowCardinality(toNullable(8))]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x00000000103acdd9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:14:40.304538 [ 16819 ] {8378c3b3-4861-45aa-98c6-b2d73da13512} executeQuery: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT CAST('test', 'IPv6'). (CANNOT_PARSE_IPV6) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:44532) (comment: 02234_cast_to_ip_address.sql) (query 51, line 74) (in query: SELECT cast('test' , 'IPv6');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000015ff2dd3 5. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000015feff79 6. bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000015fef880 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015fef682 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:14:40.306030 [ 16819 ] {} TCPHandler: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT CAST('test', 'IPv6'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000015ff2dd3 5. COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000015feff79 6. bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000015fef880 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015fef682 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 9. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:14:41.391977 [ 16822 ] {63a2a61d-35f0-4ccc-bae5-44b712cd99d0} executeQuery: Code: 41. DB::Exception: Cannot parse time component of DateTime 09:58:0: while converting '2024-08-06 09:58:0' to DateTime. (CANNOT_PARSE_DATETIME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:50942) (comment: 03231_test_incorrect_datetime_msan.sh) (query 1, line 1) (in query: SELECT count(*) FROM tab WHERE a = '2024-08-06 09:58:0'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000088dac80 4. ./build_docker/./src/IO/ReadHelpers.cpp:1549: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x0000000010c4c843 5. ./src/IO/ReadHelpers.h:1113: void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x00000000140651fc 6. ./build_docker/./src/DataTypes/Serializations/SerializationDateTime.cpp:24: DB::SerializationDateTime::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001752f222 7. ./build_docker/./src/DataTypes/Serializations/SerializationDateTime.cpp:102: DB::SerializationDateTime::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001752f0db 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd6adf 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 10. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6897d0 11. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6740a5 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 19. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000001c0b4ee0 20. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000001c321a81 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000001895e815 22. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898e9cd 23. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x00000000189866e7 24. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:14:41.394097 [ 16822 ] {} TCPHandler: Code: 41. DB::Exception: Cannot parse time component of DateTime 09:58:0: while converting '2024-08-06 09:58:0' to DateTime. (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000088dac80 4. ./build_docker/./src/IO/ReadHelpers.cpp:1549: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x0000000010c4c843 5. ./src/IO/ReadHelpers.h:1113: void DB::readDateTimeTextImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x00000000140651fc 6. ./build_docker/./src/DataTypes/Serializations/SerializationDateTime.cpp:24: DB::SerializationDateTime::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001752f222 7. ./build_docker/./src/DataTypes/Serializations/SerializationDateTime.cpp:102: DB::SerializationDateTime::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001752f0db 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd6adf 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 10. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6897d0 11. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6740a5 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 19. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000001c0b4ee0 20. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000001c321a81 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000001895e815 22. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898e9cd 23. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x00000000189866e7 24. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:14:41.913721 [ 16822 ] {415352ea-1fc5-42ed-a521-165d4eb85fc0} executeQuery: Code: 53. DB::Exception: Cannot convert string '2024-08-0 09:58:09' to type DateTime. (TYPE_MISMATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:50976) (comment: 03231_test_incorrect_datetime_msan.sh) (query 1, line 1) (in query: SELECT count(*) FROM tab WHERE a = '2024-08-0 09:58:09'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd7b5c 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6897d0 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6740a5 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000001c0b4ee0 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000001c321a81 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000001895e815 18. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898e9cd 19. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x00000000189866e7 20. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:14:41.915830 [ 16822 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '2024-08-0 09:58:09' to type DateTime. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd7b5c 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6897d0 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6740a5 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000001c0b4ee0 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000001c321a81 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000001895e815 18. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898e9cd 19. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x00000000189866e7 20. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:14:43.074253 [ 1861 ] {8d815922-7af6-4dfc-af01-baaec3158cdc} executeQuery: Code: 111. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(111_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(111_Int16, 'Int16'_String)) UInt8 : 4'. (CANNOT_MANIPULATE_SIGSET) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51044) (comment: 03172_error_log_table_not_empty.sh) (query 1, line 2) (in query: SELECT throwIf(true, 'error_log', toInt16(111)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:14:43.075511 [ 1861 ] {} TCPHandler: Code: 111. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(111_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(111_Int16, 'Int16'_String)) UInt8 : 4'. (CANNOT_MANIPULATE_SIGSET), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:14:43.086511 [ 1861 ] {05f3e02c-315b-4603-98a4-b2df7ce64098} executeQuery: Code: 222. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(222_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(222_Int16, 'Int16'_String)) UInt8 : 4'. () (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51044) (comment: 03172_error_log_table_not_empty.sh) (query 2, line 3) (in query: SELECT throwIf(true, 'error_log', toInt16(222)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:14:43.087264 [ 1861 ] {} TCPHandler: Code: 222. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(222_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(222_Int16, 'Int16'_String)) UInt8 : 4'. (), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:14:43.099186 [ 1861 ] {eb97d13a-cc4c-4153-92e9-1a397712a532} executeQuery: Code: 333. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(333_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(333_Int16, 'Int16'_String)) UInt8 : 4'. () (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51044) (comment: 03172_error_log_table_not_empty.sh) (query 3, line 4) (in query: SELECT throwIf(true, 'error_log', toInt16(333)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:14:43.100135 [ 1861 ] {} TCPHandler: Code: 333. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(333_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(333_Int16, 'Int16'_String)) UInt8 : 4'. (), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:14:43.372843 [ 1851 ] {} HTTPServerRequest: Got an HTTP request with no content length and no chunked/multipart encoding, it may be impossible to distinguish graceful EOF from abnormal connection loss 2025.07.28 06:14:43.544229 [ 2064 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:14:48.034510 [ 2064 ] {5bd7ad32-6707-408d-9c2e-d335ac93a0cf} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 1 UInt8 Const(size = 0, UInt8(size = 1)) 1 Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58590) (comment: 01950_aliases_bad_cast.sql) (query 1, line 1) (in query: SELECT 1, * FROM (SELECT NULL AS `1`);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000001700106c 4. ./build_docker/./src/Core/Block.cpp:41: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x0000000016fef4ed 5. ./build_docker/./src/Core/Block.cpp:211: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x0000000016feff1d 6. ./build_docker/./src/Interpreters/ActionsDAG.cpp:906: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d11d9 7. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 8. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 10. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 11. ./build_docker/./src/Planner/Planner.cpp:1828: DB::Planner::buildPlanForQueryNode() @ 0x000000001898a8ec 12. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:14:48.035770 [ 2064 ] {} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 1 UInt8 Const(size = 0, UInt8(size = 1)) 1 Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000001700106c 4. ./build_docker/./src/Core/Block.cpp:41: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x0000000016fef4ed 5. ./build_docker/./src/Core/Block.cpp:211: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x0000000016feff1d 6. ./build_docker/./src/Interpreters/ActionsDAG.cpp:906: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d11d9 7. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 8. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 10. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 11. ./build_docker/./src/Planner/Planner.cpp:1828: DB::Planner::buildPlanForQueryNode() @ 0x000000001898a8ec 12. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:14:48.045179 [ 2064 ] {fc153b71-ef08-4061-b0af-6e1cf36e8a7b} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 'xyz' String Const(size = 0, String(size = 1)) 'xyz' Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58590) (comment: 01950_aliases_bad_cast.sql) (query 2, line 2) (in query: SELECT '7', 'xyz', * FROM (SELECT NULL AS `'xyz'`);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000001700106c 4. ./build_docker/./src/Core/Block.cpp:41: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x0000000016fef4ed 5. ./build_docker/./src/Core/Block.cpp:211: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x0000000016feff1d 6. ./build_docker/./src/Interpreters/ActionsDAG.cpp:906: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d11d9 7. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 8. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 10. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 11. ./build_docker/./src/Planner/Planner.cpp:1828: DB::Planner::buildPlanForQueryNode() @ 0x000000001898a8ec 12. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:14:48.046055 [ 2064 ] {} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 'xyz' String Const(size = 0, String(size = 1)) 'xyz' Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000001700106c 4. ./build_docker/./src/Core/Block.cpp:41: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x0000000016fef4ed 5. ./build_docker/./src/Core/Block.cpp:211: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x0000000016feff1d 6. ./build_docker/./src/Interpreters/ActionsDAG.cpp:906: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d11d9 7. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 8. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 10. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 11. ./build_docker/./src/Planner/Planner.cpp:1828: DB::Planner::buildPlanForQueryNode() @ 0x000000001898a8ec 12. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:14:48.100990 [ 2095 ] {37b141b7-2d06-4757-a4d9-cca87ed42a01} executeQuery: Code: 111. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(111_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(111_Int16, 'Int16'_String)) UInt8 : 4'. (CANNOT_MANIPULATE_SIGSET) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58662) (comment: 03172_error_log_table_not_empty.sh) (query 1, line 2) (in query: SELECT throwIf(true, 'error_log', toInt16(111)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:14:48.102508 [ 2095 ] {} TCPHandler: Code: 111. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(111_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(111_Int16, 'Int16'_String)) UInt8 : 4'. (CANNOT_MANIPULATE_SIGSET), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:14:48.118628 [ 2095 ] {2afe53d5-69f7-464b-9290-db7ebe0ba5ce} executeQuery: Code: 222. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(222_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(222_Int16, 'Int16'_String)) UInt8 : 4'. () (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58662) (comment: 03172_error_log_table_not_empty.sh) (query 2, line 3) (in query: SELECT throwIf(true, 'error_log', toInt16(222)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:14:48.120246 [ 2095 ] {} TCPHandler: Code: 222. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(222_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(222_Int16, 'Int16'_String)) UInt8 : 4'. (), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:14:48.134800 [ 2095 ] {3d4709eb-c957-48f0-b38b-a2e43ae310d2} executeQuery: Code: 333. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(333_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(333_Int16, 'Int16'_String)) UInt8 : 4'. () (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58662) (comment: 03172_error_log_table_not_empty.sh) (query 3, line 4) (in query: SELECT throwIf(true, 'error_log', toInt16(333)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:14:48.136333 [ 2095 ] {} TCPHandler: Code: 333. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(333_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(333_Int16, 'Int16'_String)) UInt8 : 4'. (), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0ea6a 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:14:55.772788 [ 1865 ] {f32b9e9d-d07f-43ec-9bf5-bf6dfab6ca60} executeQuery: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58938) (comment: 02963_msan_agg_addBatchLookupTable8.sql) (query 1, line 1) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/58727 SELECT number % 2 AS even, aggThrow(number) FROM numbers(10) GROUP BY even;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAggThrow.cpp:71: DB::(anonymous namespace)::AggregateFunctionThrow::create(char*) const @ 0x0000000013899f53 5. ./build_docker/./src/Interpreters/Aggregator.cpp:811: void DB::Aggregator::createAggregateStates(char*&) const @ 0x0000000018468816 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1087: void std::__function::__policy_invoker::__call_impl[abi:ne190107], FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const::'lambda'(char*&), void (char*&)>>(std::__function::__policy_storage const*, char*&) @ 0x0000000018577af0 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001389ab40 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1079: void DB::Aggregator::executeImplBatch, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000001857767c 9. ./build_docker/./src/Interpreters/Aggregator.cpp:995: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x00000000185764d7 10. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x00000000184721ae 11. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x00000000183b2a0c 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b953b 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:14:55.775261 [ 1865 ] {} TCPHandler: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAggThrow.cpp:71: DB::(anonymous namespace)::AggregateFunctionThrow::create(char*) const @ 0x0000000013899f53 5. ./build_docker/./src/Interpreters/Aggregator.cpp:811: void DB::Aggregator::createAggregateStates(char*&) const @ 0x0000000018468816 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1087: void std::__function::__policy_invoker::__call_impl[abi:ne190107], FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const::'lambda'(char*&), void (char*&)>>(std::__function::__policy_storage const*, char*&) @ 0x0000000018577af0 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001389ab40 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1079: void DB::Aggregator::executeImplBatch, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000001857767c 9. ./build_docker/./src/Interpreters/Aggregator.cpp:995: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x00000000185764d7 10. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x00000000184721ae 11. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x00000000183b2a0c 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b953b 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:14:55.923652 [ 2114 ] {f7999783-d92a-4cbf-aee2-dedeaeede7fa} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(topK(4, 2, 'counts'), UInt8) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: topK instead of topK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58940) (comment: 02966_topk_counts_approx_count_sum.sql) (query 3, line 22) (in query: SELECT topKMerge(4, 3, 'counts')(state) FROM ( SELECT topKState(4, 2, 'counts')(countDigits(number * number)) AS state FROM numbers(1000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c501a5 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:14:55.925267 [ 2114 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(topK(4, 2, 'counts'), UInt8) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: topK instead of topK. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c501a5 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:14:55.938399 [ 2114 ] {f9ae3078-4252-4a65-90c0-de7cd20f3ead} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(topK(4, 2, 'counts'), UInt8) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: topK instead of topK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58940) (comment: 02966_topk_counts_approx_count_sum.sql) (query 4, line 24) (in query: SELECT topKMerge(4, 2)(state) FROM ( SELECT topKState(4, 2, 'counts')(countDigits(number * number)) AS state FROM numbers(1000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c501a5 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:14:55.939698 [ 2114 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(topK(4, 2, 'counts'), UInt8) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: topK instead of topK. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c501a5 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:14:55.950330 [ 2114 ] {23906fd0-8711-4fe3-8773-e9775fac5baf} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(topK(4, 2, 'counts'), UInt8) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: topK instead of topK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58940) (comment: 02966_topk_counts_approx_count_sum.sql) (query 5, line 26) (in query: SELECT topKMerge(state) FROM ( SELECT topKState(4, 2, 'counts')(countDigits(number * number)) AS state FROM numbers(1000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c501a5 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:14:55.951154 [ 2114 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(topK(4, 2, 'counts'), UInt8) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: topK instead of topK. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c501a5 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:14:56.775339 [ 2054 ] {fc6befda-5538-48ac-8f2e-40aff38fd0d3} executeQuery: Code: 60. DB::Exception: Table name is empty: In scope SELECT hasColumnInTable('', '', ''). (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58994) (comment: 00386_has_column_in_table.sql) (query 18, line 23) (in query: /* bad queries */ SELECT hasColumnInTable('', '', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9812d3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:14:56.776530 [ 2054 ] {} TCPHandler: Code: 60. DB::Exception: Table name is empty: In scope SELECT hasColumnInTable('', '', ''). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9812d3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:14:56.910318 [ 2054 ] {1a24cfe9-cb56-4c98-a015-a682340389a0} executeQuery: Code: 81. DB::Exception: Empty database name: In scope SELECT hasColumnInTable('', 't', 'c'). (UNKNOWN_DATABASE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58994) (comment: 00386_has_column_in_table.sql) (query 19, line 25) (in query: SELECT hasColumnInTable('', 't', 'c');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:409: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182ccd90 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 6. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b980473 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:14:56.911573 [ 2054 ] {} TCPHandler: Code: 81. DB::Exception: Empty database name: In scope SELECT hasColumnInTable('', 't', 'c'). (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:409: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182ccd90 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 6. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b980473 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:14:56.919697 [ 2054 ] {ced59553-accc-4e43-998f-97b72fb692d3} executeQuery: Code: 60. DB::Exception: Table name is empty: In scope SELECT hasColumnInTable(currentDatabase(), '', 'c'). (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58994) (comment: 00386_has_column_in_table.sql) (query 20, line 26) (in query: SELECT hasColumnInTable(currentDatabase(), '', 'c');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9812d3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:14:56.920660 [ 2054 ] {} TCPHandler: Code: 60. DB::Exception: Table name is empty: In scope SELECT hasColumnInTable(currentDatabase(), '', 'c'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9812d3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:14:57.051616 [ 2054 ] {ee742da5-4c9f-4162-9411-6f4959798275} executeQuery: Code: 81. DB::Exception: Database d does not exist: In scope SELECT hasColumnInTable('d', 't', 's'). (UNKNOWN_DATABASE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58994) (comment: 00386_has_column_in_table.sql) (query 21, line 27) (in query: SELECT hasColumnInTable('d', 't', 's');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:427: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cda58 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 6. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b980473 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:14:57.052996 [ 2054 ] {} TCPHandler: Code: 81. DB::Exception: Database d does not exist: In scope SELECT hasColumnInTable('d', 't', 's'). (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:427: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cda58 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 6. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b980473 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:14:57.189814 [ 2054 ] {11fd2900-9c84-48f5-8472-db82fc2a1507} executeQuery: Code: 60. DB::Exception: Table test_q1ku97gb.t does not exist: In scope SELECT hasColumnInTable(currentDatabase(), 't', 's'). (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58994) (comment: 00386_has_column_in_table.sql) (query 22, line 28) (in query: SELECT hasColumnInTable(currentDatabase(), 't', 's');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b980473 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:14:57.191018 [ 2054 ] {} TCPHandler: Code: 60. DB::Exception: Table test_q1ku97gb.t does not exist: In scope SELECT hasColumnInTable(currentDatabase(), 't', 's'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b980473 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:14:57.316230 [ 1855 ] {97c1dfd6-be5c-4f3e-b03b-df33023fe122} executeQuery: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt8(1)). (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51350) (comment: 00800_function_java_hash_with_unsigined_types.sh) (query 1, line 1) (in query: SELECT javaHash(toUInt8(1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c93eb6 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c9331c 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000008c92abc 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9242a 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089fe5fc 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9213e 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:14:57.318715 [ 1855 ] {} TCPHandler: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt8(1)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c93eb6 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c9331c 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000008c92abc 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9242a 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089fe5fc 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9213e 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:14:58.130078 [ 1861 ] {a2964dd6-1fdf-4ede-bed0-3148ca34334f} executeQuery: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt16(1)). (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51364) (comment: 00800_function_java_hash_with_unsigined_types.sh) (query 1, line 1) (in query: SELECT javaHash(toUInt16(1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c9427a 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c93298 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000008c92abc 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9242a 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089fe5fc 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9213e 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:14:58.132533 [ 1861 ] {} TCPHandler: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt16(1)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c9427a 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c93298 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000008c92abc 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9242a 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089fe5fc 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9213e 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:14:58.851729 [ 17043 ] {ac32bbf2-0128-4837-8758-0c847ab56b3b} executeQuery: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt32(1)). (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51402) (comment: 00800_function_java_hash_with_unsigined_types.sh) (query 1, line 1) (in query: SELECT javaHash(toUInt32(1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c9463a 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c933a4 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000008c92abc 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9242a 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089fe5fc 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9213e 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:14:58.854148 [ 17043 ] {} TCPHandler: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt32(1)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c9463a 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c933a4 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000008c92abc 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9242a 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089fe5fc 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9213e 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:14:59.585909 [ 1861 ] {f80c4a8c-046f-43d7-86ba-0f219f6da3f9} executeQuery: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt64(1)). (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51430) (comment: 00800_function_java_hash_with_unsigined_types.sh) (query 1, line 1) (in query: SELECT javaHash(toUInt64(1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c949fa 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c933ba 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000008c92abc 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9242a 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089fe5fc 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9213e 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:14:59.587917 [ 1861 ] {} TCPHandler: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt64(1)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c949fa 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x0000000008c933ba 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x0000000008c92abc 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9242a 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089fe5fc 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c9213e 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:15:01.200896 [ 16973 ] {3ed0953c-2ea9-424f-857e-38702a5f928b} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `ToDro` to drop. Maybe you meant: ['ToDrop']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51510) (comment: 02250_hints_for_columns.sh) (query 1, line 1) (in query: ALTER TABLE t DROP COLUMN ToDro), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:15:01.202747 [ 16973 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `ToDro` to drop. Maybe you meant: ['ToDrop']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:15:01.290520 [ 2114 ] {44631361-e216-48da-95a8-f4bfaee5dffc} executeQuery: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 0.9998999834060669). (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51514) (comment: 01717_int_div_float_too_large_ubsan.sql) (query 1, line 1) (in query: SELECT intDiv(18446744073709551615, 0.9998999834060669);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x000000000ba57ae4 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bca3807 6. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000000bc97e1f 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc97751 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc6bb61 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc66e33 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc65846 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc6447e 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:15:01.291668 [ 2114 ] {} TCPHandler: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 0.9998999834060669). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x000000000ba57ae4 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bca3807 6. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000000bc97e1f 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc97751 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc6bb61 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc66e33 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc65846 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc6447e 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:15:01.299551 [ 2114 ] {b0a2ff55-af1d-4888-bc0c-5260377b0651} executeQuery: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 1.). (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51514) (comment: 01717_int_div_float_too_large_ubsan.sql) (query 2, line 2) (in query: SELECT intDiv(18446744073709551615, 1.);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x000000000ba57ae4 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bca3807 6. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000000bc97e1f 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc97751 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc6bb61 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc66e33 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc65846 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc6447e 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:15:01.300938 [ 2114 ] {} TCPHandler: Code: 153. DB::Exception: Cannot perform integer division, because it will produce infinite or too large number: In scope SELECT intDiv(18446744073709551615, 1.). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. long DB::DivideIntegralImpl::apply(unsigned long, double) @ 0x000000000ba57ae4 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bca3807 6. auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000000bc97e1f 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc97751 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc6bb61 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc66e33 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc65846 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc6447e 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:15:01.784802 [ 16973 ] {e12d3ae5-187a-499c-832c-b5c74cce3cfe} executeQuery: Code: 10. DB::Exception: Wrong column. Cannot find column `ToDro` to modify. Maybe you meant: ['ToDrop']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51536) (comment: 02250_hints_for_columns.sh) (query 1, line 1) (in query: ALTER TABLE t MODIFY COLUMN ToDro UInt64), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Storages/AlterCommands.cpp:1479: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9dfd79 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:01.786863 [ 16973 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column. Cannot find column `ToDro` to modify. Maybe you meant: ['ToDrop']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Storages/AlterCommands.cpp:1479: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9dfd79 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:02.352763 [ 16822 ] {ab7fe4ac-d36d-49db-af7d-0cfe85856416} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `ToDro` to rename. Maybe you meant: ['ToDrop']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51574) (comment: 02250_hints_for_columns.sh) (query 1, line 1) (in query: ALTER TABLE t RENAME COLUMN ToDro to ToDropp), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1669: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9dfc26 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:15:02.354468 [ 16822 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `ToDro` to rename. Maybe you meant: ['ToDrop']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1669: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9dfc26 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:15:03.165015 [ 2054 ] {10f4e780-9b3e-4657-9cb6-d90e070cfe2d} executeQuery: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value3` UInt64)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51622) (comment: 01413_allow_non_metadata_alters.sql) (query 4, line 17) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value3 UInt64;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3517: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b32ae14 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:03.166151 [ 2054 ] {} TCPHandler: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value3` UInt64)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3517: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b32ae14 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:03.173765 [ 2054 ] {987c7d89-9dd8-4c28-9ee0-48fb58b7dc2d} executeQuery: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value1` UInt32)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51622) (comment: 01413_allow_non_metadata_alters.sql) (query 5, line 19) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value1 UInt32;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3517: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b32ae14 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:03.174609 [ 2054 ] {} TCPHandler: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value1` UInt32)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3517: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b32ae14 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:03.181712 [ 2054 ] {bc0a2c25-65e6-44e7-beba-a2ca63d3ad8e} executeQuery: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value4` Date)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51622) (comment: 01413_allow_non_metadata_alters.sql) (query 6, line 21) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value4 Date;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3517: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b32ae14 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:03.182613 [ 2054 ] {} TCPHandler: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value4` Date)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3517: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b32ae14 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:03.189566 [ 2054 ] {43d10766-7e0c-48b1-9914-63c8342f1dc9} executeQuery: Code: 524. DB::Exception: The following alter commands: '(DROP COLUMN value4)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51622) (comment: 01413_allow_non_metadata_alters.sql) (query 7, line 23) (in query: ALTER TABLE non_metadata_alters DROP COLUMN value4;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3517: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b32ae14 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:03.191104 [ 2054 ] {} TCPHandler: Code: 524. DB::Exception: The following alter commands: '(DROP COLUMN value4)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3517: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b32ae14 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:03.198857 [ 2054 ] {1719f747-adb4-4c75-b0e2-7d905a1d9371} executeQuery: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value2` Enum8('x' = 5, 'y' = 6))' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51622) (comment: 01413_allow_non_metadata_alters.sql) (query 8, line 25) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value2 Enum8('x' = 5, 'y' = 6);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3517: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b32ae14 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:03.200314 [ 2054 ] {} TCPHandler: Code: 524. DB::Exception: The following alter commands: '(MODIFY COLUMN `value2` Enum8('x' = 5, 'y' = 6))' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3517: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b32ae14 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:03.220334 [ 2054 ] {97a34d0a-4d1a-45b6-bb19-542606846167} executeQuery: Code: 524. DB::Exception: The following alter commands: '(RENAME COLUMN value4 TO renamed_value4)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51622) (comment: 01413_allow_non_metadata_alters.sql) (query 9, line 27) (in query: ALTER TABLE non_metadata_alters RENAME COLUMN value4 TO renamed_value4;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3517: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b32ae14 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:03.221904 [ 2054 ] {} TCPHandler: Code: 524. DB::Exception: The following alter commands: '(RENAME COLUMN value4 TO renamed_value4)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3517: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b32ae14 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:03.234725 [ 2054 ] {97e635f2-bc89-4dc5-95f4-7c7f92b13fd0} executeQuery: Code: 524. DB::Exception: The following alter commands: '(MATERIALIZE TTL)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51622) (comment: 01413_allow_non_metadata_alters.sql) (query 10, line 29) (in query: ALTER TABLE non_metadata_alters MODIFY COLUMN value3 UInt16 TTL value5 + INTERVAL 5 DAY;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3517: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b32ae14 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:03.236365 [ 2054 ] {} TCPHandler: Code: 524. DB::Exception: The following alter commands: '(MATERIALIZE TTL)' will modify data on disk, but setting `allow_non_metadata_alters` is disabled. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3517: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b32ae14 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:06.735556 [ 1855 ] {aae300ce-4108-4238-91c8-6762c23c2dd9} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56956) (comment: 02947_non_post_request_should_be_readonly.sh) (in query: CREATE DATABASE non_post_request_test_test_m8f17bef ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d05c1f 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x0000000016d03d24 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d1449d 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2345: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5c01 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:15:06.736656 [ 1855 ] {aae300ce-4108-4238-91c8-6762c23c2dd9} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d05c1f 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x0000000016d03d24 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d1449d 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2345: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5c01 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:15:06.748961 [ 1855 ] {927a6577-655b-4f52-9e5e-03f22ba0bd51} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56958) (comment: 02947_non_post_request_should_be_readonly.sh) (in query: CREATE DATABASE non_post_request_test_test_m8f17bef ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d05c1f 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x0000000016d03d24 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d1449d 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2345: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5c01 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:15:06.749741 [ 1855 ] {927a6577-655b-4f52-9e5e-03f22ba0bd51} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d05c1f 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x0000000016d03d24 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d1449d 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2345: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5c01 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:15:07.390188 [ 1855 ] {12bb2c7d-b597-4599-9e0d-71782edc5f15} executeQuery: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45832) (comment: 00716_allow_ddl.sql) (query 3, line 4) (in query: CREATE DATABASE some_db;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d05c1f 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x0000000016d03d24 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d1449d 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2345: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5c01 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:15:07.391622 [ 1855 ] {} TCPHandler: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d05c1f 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x0000000016d03d24 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d1449d 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2345: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5c01 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:15:07.471837 [ 16973 ] {779b95f2-5b44-4f45-9557-ccfce494d812} executeQuery: Code: 248. DB::Exception: Invalid partition format: 20210325_0_13241_6_12747. (INVALID_PARTITION_VALUE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45836) (comment: 01925_broken_partition_id_zookeeper.sql) (query 3, line 14) (in query: ALTER TABLE broken_partition DROP PARTITION ID '20210325_0_13241_6_12747';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:49: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x000000001b50489a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6222: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x000000001b32d63d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5406: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x000000001b34ed36 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a01b5 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:07.472773 [ 16973 ] {} TCPHandler: Code: 248. DB::Exception: Invalid partition format: 20210325_0_13241_6_12747. (INVALID_PARTITION_VALUE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:49: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x000000001b50489a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6222: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x000000001b32d63d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5406: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x000000001b34ed36 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a01b5 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:07.479009 [ 16973 ] {36683add-dfe1-45a2-a389-4301ef37221f} executeQuery: Code: 248. DB::Exception: Invalid partition format: 20210325_0_13241_6_12747. (INVALID_PARTITION_VALUE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45836) (comment: 01925_broken_partition_id_zookeeper.sql) (query 4, line 16) (in query: ALTER TABLE broken_partition DROP PARTITION ID '20210325_0_13241_6_12747';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:49: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x000000001b50489a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6222: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x000000001b32d63d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5406: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x000000001b34ed36 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a01b5 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:07.479854 [ 16973 ] {} TCPHandler: Code: 248. DB::Exception: Invalid partition format: 20210325_0_13241_6_12747. (INVALID_PARTITION_VALUE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:49: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x000000001b50489a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6222: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x000000001b32d63d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5406: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x000000001b34ed36 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a01b5 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:07.497372 [ 1855 ] {0e208160-668b-44e5-a67d-3d4d28a1d151} executeQuery: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45832) (comment: 00716_allow_ddl.sql) (query 4, line 5) (in query: CREATE TABLE some_table(a Int32) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36576 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d344f2 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2345: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5c01 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:15:07.498309 [ 1855 ] {} TCPHandler: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36576 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d344f2 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2345: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5c01 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:15:07.646047 [ 1855 ] {dfbc2af8-efa7-4ed1-80b3-923b5c118d0a} executeQuery: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45832) (comment: 00716_allow_ddl.sql) (query 5, line 6) (in query: ALTER TABLE some_table DELETE WHERE 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36576 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d344f2 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:120: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889e21f 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:15:07.647056 [ 1855 ] {} TCPHandler: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36576 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d344f2 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:120: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889e21f 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:15:07.652972 [ 16973 ] {847ba505-03fb-474b-b54e-d1585e46904b} executeQuery: Code: 248. DB::Exception: Invalid partition format: 20210325_0_13241_6_12747. Partition should consist of 6 digits: YYYYMM. (INVALID_PARTITION_VALUE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45836) (comment: 01925_broken_partition_id_zookeeper.sql) (query 9, line 25) (in query: ALTER TABLE old_partition_key DROP PARTITION ID '20210325_0_13241_6_12747';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:41: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x000000001b5049e6 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6222: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x000000001b32d63d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5406: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x000000001b34ed36 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a01b5 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:07.654202 [ 16973 ] {} TCPHandler: Code: 248. DB::Exception: Invalid partition format: 20210325_0_13241_6_12747. Partition should consist of 6 digits: YYYYMM. (INVALID_PARTITION_VALUE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Storages/MergeTree/MergeTreePartInfo.cpp:41: DB::MergeTreePartInfo::validatePartitionID(std::shared_ptr const&, StrongTypedef) @ 0x000000001b5049e6 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6222: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x000000001b32d63d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5406: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x000000001b34ed36 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a01b5 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:07.787137 [ 1855 ] {bca1dcfa-ceaf-40c5-891c-665d29b39a8c} executeQuery: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45832) (comment: 00716_allow_ddl.sql) (query 6, line 7) (in query: RENAME TABLE some_table TO some_table1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36576 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d344f2 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:47: DB::InterpreterRenameQuery::execute() @ 0x000000001892711f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:15:07.788136 [ 1855 ] {} TCPHandler: Code: 392. DB::Exception: Cannot execute query. DDL queries are prohibited for the user default. (QUERY_IS_PROHIBITED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36576 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d344f2 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:47: DB::InterpreterRenameQuery::execute() @ 0x000000001892711f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:15:07.851073 [ 1855 ] {6be3ae6a-6f5a-4bd9-90e8-ece0a3f4ef1a} executeQuery: Code: 392. DB::Exception: Cannot modify 'allow_ddl' setting when DDL queries are prohibited for the user. (QUERY_IS_PROHIBITED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45832) (comment: 00716_allow_ddl.sql) (query 7, line 8) (in query: SET allow_ddl = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40885 4. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 5. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016e40223 6. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000181a89f6 7. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000018a200ec 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:15:07.851970 [ 1855 ] {} TCPHandler: Code: 392. DB::Exception: Cannot modify 'allow_ddl' setting when DDL queries are prohibited for the user. (QUERY_IS_PROHIBITED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40885 4. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 5. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016e40223 6. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000181a89f6 7. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000018a200ec 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:15:09.967239 [ 16819 ] {4c29be13-3933-4d59-ba4c-12447309d729} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has interior rings defined outside the outer boundary: In scope SELECT pointInPolygon((97.641933, 16.5076538), [(97.66905, 16.5026053), (97.667878, 16.4979175), (97.661433, 16.4917645), (97.656745, 16.4859047), (97.656745, 16.4818029), (97.658796, 16.4785801), (97.665535, 16.4753572), (97.670808, 16.4730135), (97.676082, 16.4697907), (97.680477, 16.4677398), (97.68575, 16.4686189), (97.689559, 16.4727207), (97.69454, 16.4744788), (97.698055, 16.4747718), (97.702157, 16.4724279), (97.703036, 16.4683261), (97.703036, 16.4633453), (97.702451, 16.4594354), (97.699533, 16.4539205), (97.699106, 16.4521467), (97.699896, 16.4500714), (97.701852, 16.4474887), (97.701272, 16.4460233), (97.699896, 16.4439216), (97.699857, 16.4425297), (97.700705, 16.4417585), (97.699266, 16.4404319), (97.696817, 16.439585), (97.69468, 16.4391501), (97.690854, 16.439294), (97.686571, 16.4407665), (97.683728, 16.4428458), (97.680647, 16.444719), (97.678369, 16.445322), (97.675195, 16.4448526), (97.672627, 16.4435941), (97.670568, 16.4419727), (97.667276, 16.4410039), (97.666215, 16.439402), (97.66599, 16.43656), (97.664579, 16.435632), (97.66195, 16.4344612), (97.659174, 16.4324549), (97.658693, 16.4290256), (97.659289, 16.4246502), (97.660882, 16.422609), (97.663533, 16.4225057), (97.666402, 16.4210711), (97.67148, 16.4170395), (97.673433, 16.4146478), (97.674184, 16.4124121), (97.6742, 16.4085257), (97.674894, 16.4055148), (97.675906, 16.4019452), (97.675287, 16.3996593), (97.675062, 16.3963334), (97.675798, 16.3936434), (97.675676, 16.3909321), (97.67508, 16.386655), (97.679839, 16.386241), (97.689403, 16.3726191), (97.692011, 16.372909), (97.696359, 16.3679819), (97.699866, 16.360968), (97.697233, 16.3609438), (97.693077, 16.3596272), (97.686631, 16.3584552), (97.68165, 16.3558182), (97.674619, 16.3496653), (97.667588, 16.3482003), (97.664072, 16.3502511), (97.659384, 16.3540599), (97.652353, 16.3578686), (97.649716, 16.3625565), (97.650595, 16.3672443), (97.65206, 16.3701742), (97.65206, 16.3733971), (97.651181, 16.3760339), (97.646493, 16.3763268), (97.6462, 16.3801357), (97.646786, 16.3851165), (97.643563, 16.3883393), (97.638583, 16.3889252), (97.636239, 16.392148), (97.630379, 16.3933199), (97.629132, 16.3964903), (97.624347, 16.4056104), (97.615377, 16.4165245), (97.614779, 16.4229534), (97.611938, 16.4335685), (97.613882, 16.4410439), (97.619713, 16.4461272), (97.62375, 16.4542007), (97.62345, 16.4640683), (97.618965, 16.4793181), (97.617321, 16.4884382), (97.617747, 16.4985751), (97.623301, 16.5026416), (97.629303, 16.5016624), (97.63272, 16.4986048), (97.640862, 16.498226), (97.647134, 16.5006382), (97.650873, 16.5051263), (97.654987, 16.5089598), (97.65639, 16.5118583), (97.658166, 16.5160658), (97.660395, 16.5197566), (97.66612, 16.5140318), (97.668757, 16.507879), (97.66905, 16.5026053)], [(97.666491, 16.5599384), (97.665077, 16.5589283), (97.662417, 16.5607013), (97.659315, 16.5700096), (97.655104, 16.5821991), (97.654882, 16.5855235), (97.654593, 16.5931971), (97.659381, 16.5957754), (97.669927, 16.5995844), (97.683111, 16.6022215), (97.695123, 16.6028077), (97.704206, 16.5984131), (97.704499, 16.5825917), (97.70007, 16.5731793), (97.698976, 16.572997), (97.697211, 16.5717833), (97.692114, 16.5691237), (97.684358, 16.5691235), (97.675936, 16.567572), (97.66818, 16.5611446), (97.666491, 16.5599384)], [(97.653232, 16.574263), (97.652445, 16.5679244), (97.655949, 16.5683449), (97.659594, 16.5627383), (97.659734, 16.5585335), (97.662257, 16.5550293), (97.660855, 16.5512449), (97.658613, 16.5490023), (97.659173, 16.544517), (97.654407, 16.5408727), (97.641933, 16.5363874), (97.63086, 16.5303604), (97.628057, 16.5312014), (97.625954, 16.5415736), (97.63072, 16.5613367), (97.638569, 16.5820811), (97.645017, 16.5892294), (97.649743, 16.5887155), (97.653232, 16.574263)], [(97.625696, 16.5488739), (97.623579, 16.5396268), (97.620589, 16.5423678), (97.616353, 16.5530826), (97.611619, 16.5637974), (97.61112, 16.5725187), (97.613339, 16.5792777), (97.635042, 16.5874696), (97.64152, 16.5981844), (97.643015, 16.605909), (97.645756, 16.6066565), (97.650989, 16.6034172), (97.644012, 16.5984335), (97.64219, 16.5877556), (97.636038, 16.5804926), (97.63252, 16.570307), (97.628314, 16.5603089), (97.625696, 16.5488739)], [(97.607902, 16.3798949), (97.604911, 16.3719709), (97.602519, 16.3749612), (97.601323, 16.3955933), (97.604014, 16.406059), (97.604762, 16.4084511), (97.607896, 16.4081673), (97.609397, 16.397537), (97.609397, 16.3882674), (97.607902, 16.3798949)], [(97.64902, 16.5107163), (97.645437, 16.5073734), (97.641933, 16.5076538), (97.641933, 16.5108776), (97.645717, 16.5160636), (97.651112, 16.5211243), (97.655721, 16.5238328), (97.656392, 16.5184349), (97.654359, 16.515696), (97.64902, 16.5107163)]). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45986) (comment: 01213_point_in_Myanmar.sql) (query 2, line 2) (in query: SELECT pointInPolygon((97.641933, 16.5076538), [(97.66905, 16.5026053), (97.667878, 16.4979175), (97.661433, 16.4917645), (97.656745, 16.4859047), (97.656745, 16.4818029), (97.658796, 16.4785801), (97.665535, 16.4753572), (97.670808, 16.4730135), (97.676082, 16.4697907), (97.680477, 16.4677398), (97.68575, 16.4686189), (97.689559, 16.4727207), (97.69454, 16.4744788), (97.698055, 16.4747718), (97.702157, 16.4724279), (97.703036, 16.4683261), (97.703036, 16.4633453), (97.702451, 16.4594354), (97.699533, 16.4539205), (97.699106, 16.4521467), (97.699896, 16.4500714), (97.701852, 16.4474887), (97.701272, 16.4460233), (97.699896, 16.4439216), (97.699857, 16.4425297), (97.700705, 16.4417585), (97.699266, 16.4404319), (97.696817, 16.439585), (97.69468, 16.4391501), (97.690854, 16.439294), (97.686571, 16.4407665), (97.683728, 16.4428458), (97.680647, 16.444719), (97.678369, 16.445322), (97.675195, 16.4448526), (97.672627, 16.4435941), (97.670568, 16.4419727), (97.667276, 16.4410039), (97.666215, 16.439402), (97.66599, 16.43656), (97.664579, 16.435632), (97.66195, 16.4344612), (97.659174, 16.4324549), (97.658693, 16.4290256), (97.659289, 16.4246502), (97.660882, 16.422609), (97.663533, 16.4225057), (97.666402, 16.4210711), (97.67148, 16.4170395), (97.673433, 16.4146478), (97.674184, 16.4124121), (97.6742, 16.4085257), (97.674894, 16.4055148), (97.675906, 16.4019452), (97.675287, 16.3996593), (97.675062, 16.3963334), (97.675798, 16.3936434), (97.675676, 16.3909321), (97.67508, 16.386655), (97.679839, 16.386241), (97.689403, 16.3726191), (97.692011, 16.372909), (97.696359, 16.3679819), (97.699866, 16.360968), (97.697233, 16.3609438), (97.693077, 16.3596272), (97.686631, 16.3584552), (97.68165, 16.3558182), (97.674619, 16.3496653), (97.667588, 16.3482003), (97.664072, 16.3502511), (97.659384, 16.3540599), (97.652353, 16.3578686), (97.649716, 16.3625565), (97.650595, 16.3672443), (97.65206, 16.3701742), (97.65206, 16.3733971), (97.651181, 16.3760339), (97.646493, 16.3763268), (97.6462, 16.3801357), (97.646786, 16.3851165), (97.643563, 16.3883393), (97.638583, 16.3889252), (97.636239, 16.392148), (97.630379, 16.3933199), (97.629132, 16.3964903), (97.624347, 16.4056104), (97.615377, 16.4165245), (97.614779, 16.4229534), (97.611938, 16.4335685), (97.613882, 16.4410439), (97.619713, 16.4461272), (97.62375, 16.4542007), (97.62345, 16.4640683), (97.618965, 16.4793181), (97.617321, 16.4884382), (97.617747, 16.4985751), (97.623301, 16.5026416), (97.629303, 16.5016624), (97.63272, 16.4986048), (97.640862, 16.498226), (97.647134, 16.5006382), (97.650873, 16.5051263), (97.654987, 16.5089598), (97.65639, 16.5118583), (97.658166, 16.5160658), (97.660395, 16.5197566), (97.66612, 16.5140318), (97.668757, 16.507879), (97.66905, 16.5026053)], [(97.666491, 16.5599384), (97.665077, 16.5589283), (97.662417, 16.5607013), (97.659315, 16.5700096), (97.655104, 16.5821991), (97.654882, 16.5855235), (97.654593, 16.5931971), (97.659381, 16.5957754), (97.669927, 16.5995844), (97.683111, 16.6022215), (97.695123, 16.6028077), (97.704206, 16.5984131), (97.704499, 16.5825917), (97.70007, 16.5731793), (97.698976, 16.572997), (97.697211, 16.5717833), (97.692114, 16.5691237), (97.684358, 16.5691235), (97.675936, 16.567572), (97.66818, 16.5611446), (97.666491, 16.5599384)], [(97.653232, 16.574263), (97.652445, 16.5679244), (97.655949, 16.5683449), (97.659594, 16.5627383), (97.659734, 16.5585335), (97.662257, 16.5550293), (97.660855, 16.5512449), (97.658613, 16.5490023), (97.659173, 16.544517), (97.654407, 16.5408727), (97.641933, 16.5363874), (97.63086, 16.5303604), (97.628057, 16.5312014), (97.625954, 16.5415736), (97.63072, 16.5613367), (97.638569, 16.5820811), (97.645017, 16.5892294), (97.649743, 16.5887155), (97.653232, 16.574263)], [(97.625696, 16.5488739), (97.623579, 16.5396268), (97.620589, 16.5423678), (97.616353, 16.5530826), (97.611619, 16.5637974), (97.61112, 16.5725187), (97.613339, 16.5792777), (97.635042, 16.5874696), (97.64152, 16.5981844), (97.643015, 16.605909), (97.645756, 16.6066565), (97.650989, 16.6034172), (97.644012, 16.5984335), (97.64219, 16.5877556), (97.636038, 16.5804926), (97.63252, 16.570307), (97.628314, 16.5603089), (97.625696, 16.5488739)], [(97.607902, 16.3798949), (97.604911, 16.3719709), (97.602519, 16.3749612), (97.601323, 16.3955933), (97.604014, 16.406059), (97.604762, 16.4084511), (97.607896, 16.4081673), (97.609397, 16.397537), (97.609397, 16.3882674), (97.607902, 16.3798949)], [(97.64902, 16.5107163), (97.645437, 16.5073734), (97.641933, 16.5076538), (97.641933, 16.5108776), (97.645717, 16.5160636), (97.651112, 16.5211243), (97.655721, 16.5238328), (97.656392, 16.5184349), (97.654359, 16.515696), (97.64902, 16.5107163)]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e28b65a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:09.970183 [ 16819 ] {} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has interior rings defined outside the outer boundary: In scope SELECT pointInPolygon((97.641933, 16.5076538), [(97.66905, 16.5026053), (97.667878, 16.4979175), (97.661433, 16.4917645), (97.656745, 16.4859047), (97.656745, 16.4818029), (97.658796, 16.4785801), (97.665535, 16.4753572), (97.670808, 16.4730135), (97.676082, 16.4697907), (97.680477, 16.4677398), (97.68575, 16.4686189), (97.689559, 16.4727207), (97.69454, 16.4744788), (97.698055, 16.4747718), (97.702157, 16.4724279), (97.703036, 16.4683261), (97.703036, 16.4633453), (97.702451, 16.4594354), (97.699533, 16.4539205), (97.699106, 16.4521467), (97.699896, 16.4500714), (97.701852, 16.4474887), (97.701272, 16.4460233), (97.699896, 16.4439216), (97.699857, 16.4425297), (97.700705, 16.4417585), (97.699266, 16.4404319), (97.696817, 16.439585), (97.69468, 16.4391501), (97.690854, 16.439294), (97.686571, 16.4407665), (97.683728, 16.4428458), (97.680647, 16.444719), (97.678369, 16.445322), (97.675195, 16.4448526), (97.672627, 16.4435941), (97.670568, 16.4419727), (97.667276, 16.4410039), (97.666215, 16.439402), (97.66599, 16.43656), (97.664579, 16.435632), (97.66195, 16.4344612), (97.659174, 16.4324549), (97.658693, 16.4290256), (97.659289, 16.4246502), (97.660882, 16.422609), (97.663533, 16.4225057), (97.666402, 16.4210711), (97.67148, 16.4170395), (97.673433, 16.4146478), (97.674184, 16.4124121), (97.6742, 16.4085257), (97.674894, 16.4055148), (97.675906, 16.4019452), (97.675287, 16.3996593), (97.675062, 16.3963334), (97.675798, 16.3936434), (97.675676, 16.3909321), (97.67508, 16.386655), (97.679839, 16.386241), (97.689403, 16.3726191), (97.692011, 16.372909), (97.696359, 16.3679819), (97.699866, 16.360968), (97.697233, 16.3609438), (97.693077, 16.3596272), (97.686631, 16.3584552), (97.68165, 16.3558182), (97.674619, 16.3496653), (97.667588, 16.3482003), (97.664072, 16.3502511), (97.659384, 16.3540599), (97.652353, 16.3578686), (97.649716, 16.3625565), (97.650595, 16.3672443), (97.65206, 16.3701742), (97.65206, 16.3733971), (97.651181, 16.3760339), (97.646493, 16.3763268), (97.6462, 16.3801357), (97.646786, 16.3851165), (97.643563, 16.3883393), (97.638583, 16.3889252), (97.636239, 16.392148), (97.630379, 16.3933199), (97.629132, 16.3964903), (97.624347, 16.4056104), (97.615377, 16.4165245), (97.614779, 16.4229534), (97.611938, 16.4335685), (97.613882, 16.4410439), (97.619713, 16.4461272), (97.62375, 16.4542007), (97.62345, 16.4640683), (97.618965, 16.4793181), (97.617321, 16.4884382), (97.617747, 16.4985751), (97.623301, 16.5026416), (97.629303, 16.5016624), (97.63272, 16.4986048), (97.640862, 16.498226), (97.647134, 16.5006382), (97.650873, 16.5051263), (97.654987, 16.5089598), (97.65639, 16.5118583), (97.658166, 16.5160658), (97.660395, 16.5197566), (97.66612, 16.5140318), (97.668757, 16.507879), (97.66905, 16.5026053)], [(97.666491, 16.5599384), (97.665077, 16.5589283), (97.662417, 16.5607013), (97.659315, 16.5700096), (97.655104, 16.5821991), (97.654882, 16.5855235), (97.654593, 16.5931971), (97.659381, 16.5957754), (97.669927, 16.5995844), (97.683111, 16.6022215), (97.695123, 16.6028077), (97.704206, 16.5984131), (97.704499, 16.5825917), (97.70007, 16.5731793), (97.698976, 16.572997), (97.697211, 16.5717833), (97.692114, 16.5691237), (97.684358, 16.5691235), (97.675936, 16.567572), (97.66818, 16.5611446), (97.666491, 16.5599384)], [(97.653232, 16.574263), (97.652445, 16.5679244), (97.655949, 16.5683449), (97.659594, 16.5627383), (97.659734, 16.5585335), (97.662257, 16.5550293), (97.660855, 16.5512449), (97.658613, 16.5490023), (97.659173, 16.544517), (97.654407, 16.5408727), (97.641933, 16.5363874), (97.63086, 16.5303604), (97.628057, 16.5312014), (97.625954, 16.5415736), (97.63072, 16.5613367), (97.638569, 16.5820811), (97.645017, 16.5892294), (97.649743, 16.5887155), (97.653232, 16.574263)], [(97.625696, 16.5488739), (97.623579, 16.5396268), (97.620589, 16.5423678), (97.616353, 16.5530826), (97.611619, 16.5637974), (97.61112, 16.5725187), (97.613339, 16.5792777), (97.635042, 16.5874696), (97.64152, 16.5981844), (97.643015, 16.605909), (97.645756, 16.6066565), (97.650989, 16.6034172), (97.644012, 16.5984335), (97.64219, 16.5877556), (97.636038, 16.5804926), (97.63252, 16.570307), (97.628314, 16.5603089), (97.625696, 16.5488739)], [(97.607902, 16.3798949), (97.604911, 16.3719709), (97.602519, 16.3749612), (97.601323, 16.3955933), (97.604014, 16.406059), (97.604762, 16.4084511), (97.607896, 16.4081673), (97.609397, 16.397537), (97.609397, 16.3882674), (97.607902, 16.3798949)], [(97.64902, 16.5107163), (97.645437, 16.5073734), (97.641933, 16.5076538), (97.641933, 16.5108776), (97.645717, 16.5160636), (97.651112, 16.5211243), (97.655721, 16.5238328), (97.656392, 16.5184349), (97.654359, 16.515696), (97.64902, 16.5107163)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e28b65a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:10.101669 [ 1859 ] {2cfbda88-ab0d-46a5-b2ef-fa59741e0159} executeQuery: Code: 43. DB::Exception: Cannot reinterpret String as FixedString because it is not fixed size and contiguous in memory: In scope SELECT reinterpret('123', 'FixedString(1)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45960) (comment: 01676_reinterpret_as.sql) (query 42, line 42) (in query: SELECT reinterpret('123', 'FixedString(1)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionReinterpret::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eab9853 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:15:10.102736 [ 1859 ] {} TCPHandler: Code: 43. DB::Exception: Cannot reinterpret String as FixedString because it is not fixed size and contiguous in memory: In scope SELECT reinterpret('123', 'FixedString(1)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionReinterpret::getReturnTypeImpl(std::vector> const&) const @ 0x000000000eab9853 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:15:10.829299 [ 1855 ] {59d847e7-e874-42cb-8d91-ff04aa656bab} executeQuery: Code: 36. DB::Exception: Fourth argument of function transform must be a constant or at least as big as the second and third arguments. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46030) (comment: 03340_transform_logical_error_fix.sql) (query 2, line 3) (in query: SELECT transform(NULL, ['', ''], ['', ''], *) FROM ( SELECT NULL );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ef3599d 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 10. DB::(anonymous namespace)::FunctionTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ef289e2 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000179c80b1 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:346: DB::ActionsDAG::addFunction(DB::FunctionNode const&, std::vector>, String) @ 0x00000000179c89c8 18. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:536: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000017a2d801 19. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x0000000017a24917 20. ./build_docker/./src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x0000000017a3c14b 21. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:380: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x00000000189fa37c 22. ./build_docker/./src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x000000001898631b 23. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:15:10.831222 [ 1855 ] {} TCPHandler: Code: 36. DB::Exception: Fourth argument of function transform must be a constant or at least as big as the second and third arguments. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ef3599d 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 10. DB::(anonymous namespace)::FunctionTransform::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ef289e2 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000179c80b1 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:346: DB::ActionsDAG::addFunction(DB::FunctionNode const&, std::vector>, String) @ 0x00000000179c89c8 18. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:536: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000017a2d801 19. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x0000000017a24917 20. ./build_docker/./src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x0000000017a3c14b 21. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:380: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x00000000189fa37c 22. ./build_docker/./src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x000000001898631b 23. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:15:10.865778 [ 16819 ] {45b9e53b-1a90-4fa8-923e-bbb2f030b464} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 4.00. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46032) (comment: 02501_limits_on_result_for_view.sql) (query 8, line 18) (in query: -- test SELECT * from 02501_view settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:15:10.868135 [ 1858 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:43360, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:15:10.868547 [ 1858 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:43360, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:15:10.878333 [ 16819 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 4.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:15:11.084089 [ 2095 ] {24c0b5ad-91bf-49bb-ac93-a67370c7d54e} executeQuery: Code: 70. DB::Exception: Value in column Int256 cannot be safely converted into type Int32: while executing 'FUNCTION in(i :: 0, __set_8900683505466073743_14142623453418815818 :: 1) -> in(__table1.i, __set_8900683505466073743_14142623453418815818) Nullable(UInt8) : 2'. (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46034) (comment: 02809_storage_set_analysis_bug.sql) (query 9, line 14) (in query: SELECT count() = 1 FROM null_in__fuzz_6 PREWHERE 71 WHERE i IN (test_set);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x000000001607d7af 5. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)::operator()>, DB::DataTypeNumber>>(DB::DataTypeNumber const&) const @ 0x000000001607644a 6. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000016074ec8 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000016074d4a 8. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x00000000161c5a9d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000161c586a 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 15. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000018dd3013 16. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000018dd3576 17. ./build_docker/./src/Interpreters/Set.cpp:470: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000018b1a0d0 18. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000000b9b9742 19. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9b8933 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 22. DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f155a1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148fe 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 26. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 27. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 28. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 29. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 30. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 2025.07.28 06:15:11.086382 [ 2095 ] {} TCPHandler: Code: 70. DB::Exception: Value in column Int256 cannot be safely converted into type Int32: while executing 'FUNCTION in(i :: 0, __set_8900683505466073743_14142623453418815818 :: 1) -> in(__table1.i, __set_8900683505466073743_14142623453418815818) Nullable(UInt8) : 2'. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x000000001607d7af 5. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)::operator()>, DB::DataTypeNumber>>(DB::DataTypeNumber const&) const @ 0x000000001607644a 6. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x0000000016074ec8 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000016074d4a 8. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x00000000161c5a9d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000161c586a 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 15. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000018dd3013 16. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000018dd3576 17. ./build_docker/./src/Interpreters/Set.cpp:470: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000018b1a0d0 18. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000000b9b9742 19. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9b8933 20. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 21. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 22. DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f155a1 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148fe 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 26. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 27. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 28. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 29. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 30. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:15:11.502248 [ 16819 ] {6d7658e7-65ed-41a1-b28f-efd6340d22f1} executeQuery: Code: 36. DB::Exception: Cannot turn rows into a ORC format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46048) (comment: 02113_format_row_bug.sql) (query 1, line 3) (in query: select formatRow('ORC', number, toDate(number)) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ab9fb76 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 15. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 16. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:15:11.503458 [ 16819 ] {} TCPHandler: Code: 36. DB::Exception: Cannot turn rows into a ORC format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ab9fb76 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 15. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 16. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:15:11.513064 [ 16819 ] {1ee14420-a6f0-4a22-9e7a-281e904fde4c} executeQuery: Code: 36. DB::Exception: Cannot turn rows into a Parquet format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46048) (comment: 02113_format_row_bug.sql) (query 2, line 4) (in query: select formatRow('Parquet', number, toDate(number)) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ab9fb76 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 15. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 16. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:15:11.513905 [ 16819 ] {} TCPHandler: Code: 36. DB::Exception: Cannot turn rows into a Parquet format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ab9fb76 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 15. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 16. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:15:11.525602 [ 16819 ] {e250cdf8-ed68-48eb-8c50-a7930ed9b07f} executeQuery: Code: 36. DB::Exception: Cannot turn rows into a Arrow format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46048) (comment: 02113_format_row_bug.sql) (query 3, line 5) (in query: select formatRow('Arrow', number, toDate(number)) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ab9fb76 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 15. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 16. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:15:11.526618 [ 16819 ] {} TCPHandler: Code: 36. DB::Exception: Cannot turn rows into a Arrow format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ab9fb76 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 15. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 16. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:15:11.537380 [ 16819 ] {d7611c45-77a3-44e0-81fb-2cfa1c61bbcf} executeQuery: Code: 36. DB::Exception: Cannot turn rows into a Native format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46048) (comment: 02113_format_row_bug.sql) (query 4, line 6) (in query: select formatRow('Native', number, toDate(number)) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ab9fb76 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 15. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 16. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:15:11.538330 [ 16819 ] {} TCPHandler: Code: 36. DB::Exception: Cannot turn rows into a Native format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ab9fb76 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 15. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 16. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:15:12.172503 [ 16973 ] {2f46bbeb-f3ab-41ba-90d2-ff2c67a5eb55} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `z` in scope SELECT x, y, z FROM aliased2. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46074) (comment: 03101_analyzer_identifiers_4.sql) (query 32, line 90) (in query: SELECT x, y, z FROM aliased2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:15:12.173719 [ 16973 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `z` in scope SELECT x, y, z FROM aliased2. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:15:13.826997 [ 1865 ] {faa14e0b-7516-4907-9e8a-dfe534322f82} executeQuery: Code: 59. DB::Exception: Invalid sampling column type in storage parameters: UUID. Must be one unsigned integer type. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46126) (comment: 01942_create_table_with_sample.sql) (query 1, line 1) (in query: CREATE TABLE IF NOT EXISTS sample_incorrect (`x` UUID) ENGINE = MergeTree ORDER BY tuple(x) SAMPLE BY x SETTINGS index_granularity = 64449, min_bytes_for_wide_part = 154140546, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 522004154, compact_parts_max_granules_to_buffer = 116, compact_parts_merge_max_bytes_to_prefetch_part = 25250392, merge_max_block_size = 2855, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 6, min_merge_bytes_to_use_direct_io = 7208820677, index_granularity_bytes = 28071385, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 15561, primary_key_compress_block_size = 83022, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:342: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x000000001b2e32d5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:523: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e04c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:15:13.828703 [ 1865 ] {} TCPHandler: Code: 59. DB::Exception: Invalid sampling column type in storage parameters: UUID. Must be one unsigned integer type. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:342: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x000000001b2e32d5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:523: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e04c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:15:13.850977 [ 1855 ] {8298b4c3-ac0e-4900-830d-27e1cf55f7b9} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50644) (comment: 00305_http_and_readonly.sh) (in query: CREATE TABLE table_00305a(x Int8) ENGINE=Log ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36576 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d344f2 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2345: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5c01 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:15:13.852704 [ 1855 ] {8298b4c3-ac0e-4900-830d-27e1cf55f7b9} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36576 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d344f2 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2345: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5c01 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:15:13.991182 [ 1855 ] {} DynamicQueryHandler: Code: 164. DB::Exception: Cannot modify 'readonly' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40885 4. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 5. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016e40388 6. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000181a8486 7. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000181a8b7b 8. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1f72b 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:15:14.054392 [ 1855 ] {4110ea55-5647-44af-ade9-e916c922b5fe} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50672) (comment: 00305_http_and_readonly.sh) (in query: CREATE TABLE table_00305c(x Int8) ENGINE=Log ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36576 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d344f2 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2345: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5c01 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:15:14.055930 [ 1855 ] {4110ea55-5647-44af-ade9-e916c922b5fe} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36576 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d344f2 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2345: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5c01 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:15:14.072031 [ 1855 ] {5ceb81fb-30dd-46eb-a1b1-3e169a0e1ec2} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50686) (comment: 00305_http_and_readonly.sh) (in query: CREATE TABLE table_00305c(x Int8) ENGINE=Log ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36576 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d344f2 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2345: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5c01 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:15:14.074132 [ 1855 ] {5ceb81fb-30dd-46eb-a1b1-3e169a0e1ec2} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d36576 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, String>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, String const&) const @ 0x0000000016d344f2 6. ./build_docker/./src/Access/ContextAccess.cpp:781: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000016d14534 7. ./build_docker/./src/Access/ContextAccess.cpp:819: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000016cceff0 8. ./src/Access/ContextAccess.h:261: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000001819d417 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2345: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5c01 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:15:14.206943 [ 1855 ] {95f11d5e-98b1-4e0e-a56d-3969433f7d92} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50692) (comment: 00305_http_and_readonly.sh) (in query: DROP TABLE table_00305a ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d08eb9 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000016d06ec4 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000016cceb63 7. ./src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001819c9bc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:286: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000188eed77 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000188ed095 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000188ec24a 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000188ebf70 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:15:14.208855 [ 1855 ] {95f11d5e-98b1-4e0e-a56d-3969433f7d92} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d08eb9 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000016d06ec4 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000016cceb63 7. ./src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001819c9bc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:286: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000188eed77 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000188ed095 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000188ec24a 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000188ebf70 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:15:14.974815 [ 2054 ] {d84eebf4-17e2-4f47-b930-4cac1179d652} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 0, should be 3: In scope SELECT if(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46198) (comment: 00692_if_exception_code.sql) (query 2, line 3) (in query: SELECT if();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18abf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:15:14.975873 [ 2054 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 0, should be 3: In scope SELECT if(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18abf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:15:14.983558 [ 1865 ] {a6b81186-51f1-497f-8439-0d3342848b4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 0, should be 1: In scope SELECT byteSwap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46154) (comment: 02887_byteswap.sql) (query 34, line 46) (in query: -- Number of arguments should equal 1 SELECT byteSwap();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:15:14.985476 [ 1865 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 0, should be 1: In scope SELECT byteSwap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:15:14.986113 [ 2054 ] {50b081dc-d18a-4b57-8926-f1eaafd99d43} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 1, should be 3: In scope SELECT if(1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46198) (comment: 00692_if_exception_code.sql) (query 3, line 4) (in query: SELECT if(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18abf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:15:14.987422 [ 2054 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 1, should be 3: In scope SELECT if(1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18abf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:15:14.996804 [ 2054 ] {9843e72d-7d87-440e-a07a-c1357027bee9} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 2, should be 3: In scope SELECT if(1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46198) (comment: 00692_if_exception_code.sql) (query 4, line 5) (in query: SELECT if(1, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18abf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:15:14.998212 [ 2054 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 2, should be 3: In scope SELECT if(1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18abf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:15:14.998566 [ 1865 ] {03867b70-b942-4b6d-8adb-21269e102f3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(128, 129). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46154) (comment: 02887_byteswap.sql) (query 35, line 48) (in query: SELECT byteSwap(128, 129);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:15:15.000456 [ 1865 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(128, 129). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:15:15.145711 [ 1865 ] {87f9693c-9a06-4f6e-8e32-ac8baa2deb53} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function byteSwap: In scope SELECT byteSwap('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46154) (comment: 02887_byteswap.sql) (query 36, line 50) (in query: -- Input should be integral SELECT byteSwap('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.146817 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function byteSwap: In scope SELECT byteSwap('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.155600 [ 1865 ] {cc125220-582d-4d6a-b1d9-4824df845d57} executeQuery: Code: 43. DB::Exception: Illegal type FixedString(3) of argument of function byteSwap: In scope SELECT byteSwap(toFixedString('abc', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46154) (comment: 02887_byteswap.sql) (query 37, line 52) (in query: SELECT byteSwap(toFixedString('abc', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.156823 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type FixedString(3) of argument of function byteSwap: In scope SELECT byteSwap(toFixedString('abc', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.164914 [ 1865 ] {18985d94-ecc3-4af1-a038-f3f3807b6841} executeQuery: Code: 43. DB::Exception: Illegal type Date of argument of function byteSwap: In scope SELECT byteSwap(toDate('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46154) (comment: 02887_byteswap.sql) (query 38, line 53) (in query: SELECT byteSwap(toDate('2019-01-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.165795 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of argument of function byteSwap: In scope SELECT byteSwap(toDate('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.173996 [ 1865 ] {4588de48-bef9-4db7-beb5-6767dc9518ba} executeQuery: Code: 43. DB::Exception: Illegal type Date32 of argument of function byteSwap: In scope SELECT byteSwap(toDate32('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46154) (comment: 02887_byteswap.sql) (query 39, line 54) (in query: SELECT byteSwap(toDate32('2019-01-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.174885 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date32 of argument of function byteSwap: In scope SELECT byteSwap(toDate32('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.181735 [ 1865 ] {55ef78cf-f4db-4b32-b4f1-238f0a27c498} executeQuery: Code: 43. DB::Exception: Illegal type DateTime of argument of function byteSwap: In scope SELECT byteSwap(toDateTime32(1546300800)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46154) (comment: 02887_byteswap.sql) (query 40, line 55) (in query: SELECT byteSwap(toDateTime32(1546300800));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.182789 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime of argument of function byteSwap: In scope SELECT byteSwap(toDateTime32(1546300800)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.189959 [ 1865 ] {74f1f261-ab08-4a0c-9ab2-a4de427845d8} executeQuery: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument of function byteSwap: In scope SELECT byteSwap(toDateTime64(1546300800, 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46154) (comment: 02887_byteswap.sql) (query 41, line 56) (in query: SELECT byteSwap(toDateTime64(1546300800, 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.190905 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument of function byteSwap: In scope SELECT byteSwap(toDateTime64(1546300800, 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.197929 [ 1865 ] {59d3c3a6-ef56-4c84-a9e8-5a476b34b717} executeQuery: Code: 43. DB::Exception: Illegal type UUID of argument of function byteSwap: In scope SELECT byteSwap(generateUUIDv4()). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46154) (comment: 02887_byteswap.sql) (query 42, line 57) (in query: SELECT byteSwap(generateUUIDv4());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.198872 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UUID of argument of function byteSwap: In scope SELECT byteSwap(generateUUIDv4()). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.206454 [ 1865 ] {ae9e4234-56e2-4761-8ccf-34be708f08f0} executeQuery: Code: 43. DB::Exception: Illegal type Decimal(9, 4) of argument of function byteSwap: In scope SELECT byteSwap(toDecimal32(2, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46154) (comment: 02887_byteswap.sql) (query 43, line 58) (in query: SELECT byteSwap(toDecimal32(2, 4));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.207421 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Decimal(9, 4) of argument of function byteSwap: In scope SELECT byteSwap(toDecimal32(2, 4)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0b0159 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:15:15.346232 [ 1865 ] {5e7251f2-1115-4100-b707-527158ff4c6c} executeQuery: Code: 48. DB::Exception: byteSwap() is not implemented for float datatype: In scope SELECT byteSwap(toFloat32(123.456)). (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46154) (comment: 02887_byteswap.sql) (query 44, line 59) (in query: SELECT byteSwap(toFloat32(123.456));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::ByteSwapImpl::apply(float) @ 0x000000000a0b9cca 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000a0b9b40 6. DB::UnaryOperationImpl>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000a0b99fc 7. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a0af870 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:15:15.347701 [ 1865 ] {} TCPHandler: Code: 48. DB::Exception: byteSwap() is not implemented for float datatype: In scope SELECT byteSwap(toFloat32(123.456)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::ByteSwapImpl::apply(float) @ 0x000000000a0b9cca 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000a0b9b40 6. DB::UnaryOperationImpl>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000a0b99fc 7. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a0af870 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:15:15.477869 [ 1865 ] {a852ea21-73dc-4791-979a-e2ad2f75ccfe} executeQuery: Code: 48. DB::Exception: byteSwap() is not implemented for double datatype: In scope SELECT byteSwap(toFloat64(123.456)). (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46154) (comment: 02887_byteswap.sql) (query 45, line 60) (in query: SELECT byteSwap(toFloat64(123.456));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::ByteSwapImpl::apply(double) @ 0x000000000a0ba06a 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000a0b9ee0 6. DB::UnaryOperationImpl>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000a0b9d9c 7. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a0af945 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:15:15.479348 [ 1865 ] {} TCPHandler: Code: 48. DB::Exception: byteSwap() is not implemented for double datatype: In scope SELECT byteSwap(toFloat64(123.456)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::ByteSwapImpl::apply(double) @ 0x000000000a0ba06a 5. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000a0b9ee0 6. DB::UnaryOperationImpl>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000a0b9d9c 7. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a0af945 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:15:16.112018 [ 1858 ] {4bb7e324-a42a-4ac5-99ae-a8ea6f32e736} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(any, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46242) (comment: 02922_respect_nulls_states.sql) (query 10, line 13) (in query: SELECT first_value_respect_nullsMerge(t) FROM (Select first_valueState(number) as t from numbers(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c501a5 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:15:16.113761 [ 1858 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(any, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c501a5 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:15:16.126226 [ 1858 ] {cc40c46f-1337-4ffd-a2ae-2b8a028bbee6} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(anyLast_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: anyLast_respect_nulls instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46242) (comment: 02922_respect_nulls_states.sql) (query 11, line 14) (in query: SELECT first_value_respect_nullsMerge(t) FROM (Select last_value_respect_nullsState(number) as t from numbers(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c501a5 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:15:16.128022 [ 1858 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(anyLast_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: anyLast_respect_nulls instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c501a5 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:15:16.142150 [ 1858 ] {7c4ecad1-07e4-4e24-8cd6-abf4b86d1502} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nulls instead of anyLast_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46242) (comment: 02922_respect_nulls_states.sql) (query 12, line 15) (in query: SELECT last_value_respect_nullsMerge(t) FROM (Select first_value_respect_nullsState(number) as t from numbers(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c501a5 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:15:16.143921 [ 1858 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(any_respect_nulls, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any_respect_nulls instead of anyLast_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c501a5 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:15:16.156031 [ 1858 ] {75ca0c39-3ccc-4a61-8837-86636bf270fa} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(any, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46242) (comment: 02922_respect_nulls_states.sql) (query 13, line 16) (in query: SELECT first_value_respect_nullsMerge(CAST(unhex('00'), 'AggregateFunction(any, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c501a5 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:15:16.157444 [ 1858 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(any, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: any instead of any_respect_nulls. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000013c501a5 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000164715bc 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:15:16.305632 [ 1858 ] {9b22eabe-5e56-4dea-8b3e-d8880a9f942e} executeQuery: Code: 117. DB::Exception: Incorrect type (0) in any_respect_nullsState: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('00'), 'AggregateFunction(any_respect_nulls, UInt64)')). (INCORRECT_DATA) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46242) (comment: 02922_respect_nulls_states.sql) (query 14, line 18) (in query: -- Invalid (starts at 1) SELECT first_value_respect_nullsMerge(CAST(unhex('00'), 'AggregateFunction(any_respect_nulls, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception<_BitInt(8), std::basic_string, std::basic_string::allocator>>(int, FormatStringHelperImpl::type, std::basic_string::type_identity, std::basic_string::allocator>>::type>, std::basic_string::type_identity<_BitInt(8)>&&, std::basic_string::type_identity, std::basic_string::allocator>>&&) @ 0x000000001274e726 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:171: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000012748328 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000001751a29d 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001751a5bf 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000015fd9bd3 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000015fd88e2 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000161c3c30 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 2025.07.28 06:15:16.307285 [ 1858 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect type (0) in any_respect_nullsState: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('00'), 'AggregateFunction(any_respect_nulls, UInt64)')). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception<_BitInt(8), std::basic_string, std::basic_string::allocator>>(int, FormatStringHelperImpl::type, std::basic_string::type_identity, std::basic_string::allocator>>::type>, std::basic_string::type_identity<_BitInt(8)>&&, std::basic_string::type_identity, std::basic_string::allocator>>&&) @ 0x000000001274e726 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:171: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000012748328 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000001751a29d 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001751a5bf 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000015fd9bd3 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000015fd88e2 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000161c3c30 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 2025.07.28 06:15:16.503282 [ 1858 ] {c033bdef-b79e-463b-b550-328ea930a2ec} executeQuery: Code: 117. DB::Exception: Incorrect type (NULL) in non-nullable any_respect_nullsState: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('02'), 'AggregateFunction(any_respect_nulls, UInt64)')). (INCORRECT_DATA) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46242) (comment: 02922_respect_nulls_states.sql) (query 17, line 23) (in query: -- Set to NULL SELECT first_value_respect_nullsMerge(CAST(unhex('02'), 'AggregateFunction(any_respect_nulls, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:163: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000012747bae 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000001751a29d 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001751a5bf 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000015fd9bd3 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000015fd88e2 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000161c3c30 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 2025.07.28 06:15:16.504719 [ 1858 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect type (NULL) in non-nullable any_respect_nullsState: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('02'), 'AggregateFunction(any_respect_nulls, UInt64)')). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:163: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000012747bae 5. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000001751a29d 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001751a5bf 7. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000015fd9bd3 8. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000015fd88e2 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000161c3c30 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 2025.07.28 06:15:16.677930 [ 1858 ] {c5ad483e-371a-44db-8084-3fe1f6bc5939} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 8.: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('03'), 'AggregateFunction(any_respect_nulls, UInt64)')). (CANNOT_READ_ALL_DATA) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46242) (comment: 02922_respect_nulls_states.sql) (query 20, line 28) (in query: -- Set to other value, but without providing value SELECT first_value_respect_nullsMerge(CAST(unhex('03'), 'AggregateFunction(any_respect_nulls, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ac8c7a6 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000010c2a88d 5. ./src/IO/ReadHelpers.h:117: DB::SerializationNumber::deserializeBinary(DB::Field&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000175a1a2d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:168: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000012748235 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000001751a29d 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001751a5bf 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000015fd9bd3 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000015fd88e2 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000161c3c30 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 2025.07.28 06:15:16.679091 [ 1858 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 8.: In scope SELECT first_value_respect_nullsMerge(CAST(unhex('03'), 'AggregateFunction(any_respect_nulls, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ac8c7a6 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000010c2a88d 5. ./src/IO/ReadHelpers.h:117: DB::SerializationNumber::deserializeBinary(DB::Field&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000175a1a2d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnyRespectNulls.cpp:168: DB::(anonymous namespace)::AggregateFunctionAnyRespectNulls::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000012748235 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000001751a29d 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001751a5bf 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x0000000015fd9bd3 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000015fd88e2 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000161c3c30 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 2025.07.28 06:15:17.437696 [ 2095 ] {c7ef3656-b330-41f9-bc6a-14734bec97ec} executeQuery: Code: 182. DB::Exception: Table expression test_svqbws9q.merge1 AS __table1 does not support column __table1.Val in PREWHERE. In query SELECT Val FROM merge1 PREWHERE (Val = 65536) OR (Val = 2). (ILLEGAL_PREWHERE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36232) (comment: 02527_storage_merge_prewhere_different_type.sql) (query 7, line 9) (in query: SELECT Val FROM merge1 PREWHERE Val = 65536 OR Val = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f1942d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f19165 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f19165 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f19165 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f19165 9. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000017f1616b 10. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x000000001898327c 11. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:15:17.438901 [ 2095 ] {} TCPHandler: Code: 182. DB::Exception: Table expression test_svqbws9q.merge1 AS __table1 does not support column __table1.Val in PREWHERE. In query SELECT Val FROM merge1 PREWHERE (Val = 65536) OR (Val = 2). (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f1942d 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f19165 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f19165 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f19165 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017f19165 9. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000017f1616b 10. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x000000001898327c 11. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:15:17.505611 [ 2114 ] {ecab77fe-01ba-4821-afbf-7d17e833b6d9} executeQuery: Code: 36. DB::Exception: Point (1.8446744073709552e+19, 1.8446744073709552e+19) is invalid in function geoToS2. For valid point the latitude is between -90 and 90 degrees inclusiveand the longitude is between -180 and 180 degrees inclusive.: In scope SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1))). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36244) (comment: 02816_s2_invalid_point.sql) (query 1, line 3) (in query: SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, double const&, double const&, String&&) @ 0x000000000ac8610c 4. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ac85b2f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:15:17.506847 [ 2114 ] {} TCPHandler: Code: 36. DB::Exception: Point (1.8446744073709552e+19, 1.8446744073709552e+19) is invalid in function geoToS2. For valid point the latitude is between -90 and 90 degrees inclusiveand the longitude is between -180 and 180 degrees inclusive.: In scope SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1))). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, double const&, double const&, String&&) @ 0x000000000ac8610c 4. DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ac85b2f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:15:18.698465 [ 1860 ] {0ab95820-7e79-494c-b88e-627d3fdb9285} executeQuery: Code: 388. DB::Exception: Cannot OPTIMIZE table: There is an outdated part in a gap between two active parts (all_2_2_0, all_4_4_0) with merge level 1 higher than these active parts have. (CANNOT_ASSIGN_OPTIMIZE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36302) (comment: 02521_merge_over_gap.sh) (query 1, line 1) (in query: OPTIMIZE TABLE table_with_gap FINAL SETTINGS optimize_throw_if_noop=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1698: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000001b7cce84 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000018e805fd 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:15:18.700388 [ 1860 ] {} TCPHandler: Code: 388. DB::Exception: Cannot OPTIMIZE table: There is an outdated part in a gap between two active parts (all_2_2_0, all_4_4_0) with merge level 1 higher than these active parts have. (CANNOT_ASSIGN_OPTIMIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1698: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000001b7cce84 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000018e805fd 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:15:18.770958 [ 1859 ] {6940522a-dc4f-4e0b-beed-6f833dee840d} executeQuery: Code: 69. DB::Exception: A call to function range would produce 18446744073709550590 array elements, which is greater than the allowed maximum of 500000000: In scope SELECT range(1025, 18446744073709551615, 1). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36294) (comment: 01408_range_overflow.sql) (query 3, line 4) (in query: SELECT range(1025, 18446744073709551615, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. COW::immutable_ptr DB::FunctionRange::executeGeneric(DB::IColumn const*, DB::IColumn const*, DB::IColumn const*, unsigned long) const @ 0x0000000010aab561 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000010a93e71 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:15:18.772137 [ 1859 ] {} TCPHandler: Code: 69. DB::Exception: A call to function range would produce 18446744073709550590 array elements, which is greater than the allowed maximum of 500000000: In scope SELECT range(1025, 18446744073709551615, 1). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. COW::immutable_ptr DB::FunctionRange::executeGeneric(DB::IColumn const*, DB::IColumn const*, DB::IColumn const*, unsigned long) const @ 0x0000000010aab561 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000010a93e71 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:15:22.481864 [ 1851 ] {cc30da2f-b01d-4c0d-8419-e2ae9b34a261} executeQuery: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36470) (comment: 01493_alter_remove_wrong_default.sql) (query 3, line 11) (in query: ALTER TABLE default_table MODIFY COLUMN key REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e0672 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:22.483830 [ 1851 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e0672 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:22.568415 [ 1851 ] {1091be83-21f4-4e41-b4fd-0a2d48561f33} executeQuery: Code: 36. DB::Exception: Cannot remove ALIAS from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36470) (comment: 01493_alter_remove_wrong_default.sql) (query 4, line 12) (in query: ALTER TABLE default_table MODIFY COLUMN key REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e0795 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:22.570120 [ 1851 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove ALIAS from column `key`, because column default type is DEFAULT. Use REMOVE DEFAULT to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e0795 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:22.662961 [ 1851 ] {8d4b894e-1ce1-46eb-ba82-09dcad0a040a} executeQuery: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36470) (comment: 01493_alter_remove_wrong_default.sql) (query 5, line 14) (in query: ALTER TABLE default_table MODIFY COLUMN value1 REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e054f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:22.664959 [ 1851 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e054f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:22.673133 [ 1851 ] {5edd6926-4906-4f8c-ac49-99d1264dd1be} executeQuery: Code: 36. DB::Exception: Cannot remove ALIAS from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36470) (comment: 01493_alter_remove_wrong_default.sql) (query 6, line 15) (in query: ALTER TABLE default_table MODIFY COLUMN value1 REMOVE ALIAS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e0795 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:22.674520 [ 1851 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove ALIAS from column `value1`, because column default type is MATERIALIZED. Use REMOVE MATERIALIZED to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Storages/AlterCommands.cpp:1520: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e0795 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:22.680432 [ 1851 ] {e8987da1-93ca-4c02-9e3a-6f69c1d0d847} executeQuery: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36470) (comment: 01493_alter_remove_wrong_default.sql) (query 7, line 17) (in query: ALTER TABLE default_table MODIFY COLUMN value2 REMOVE DEFAULT;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e054f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:22.681417 [ 1851 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove DEFAULT from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Storages/AlterCommands.cpp:1506: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e054f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:22.688226 [ 1851 ] {d4e2cca4-ce9f-4657-baa1-5c49641c5afe} executeQuery: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36470) (comment: 01493_alter_remove_wrong_default.sql) (query 8, line 18) (in query: ALTER TABLE default_table MODIFY COLUMN value2 REMOVE MATERIALIZED;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e0672 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:22.689459 [ 1851 ] {} TCPHandler: Code: 36. DB::Exception: Cannot remove MATERIALIZED from column `value2`, because column default type is ALIAS. Use REMOVE ALIAS to delete it. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/Storages/AlterCommands.cpp:1513: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e0672 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:31.206545 [ 1032 ] {de18d6e4-1b82-4007-880b-6b773c33253a::all_0_0_1} de18d6e4-1b82-4007-880b-6b773c33253a::all_0_0_1 (MergeFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: uncompressed hash of compressed files doesn't match (56fb85e7e5b8d127edbb1f4cee6f08f2 vs 890660bf49789856de30d56e37ee7b46). (CHECKSUM_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 1 (db7b13ffcb46ab2bbdf9b8450495b777) data.bin: 87 (f0ad9c2fbdc8cdaf87d56f3e26618ed2) data.cmrk3: 58 (cb8a5542a0bc133e10c91a23fb7183a7) primary.cidx: 42 (10356a73f3f7cd67e05a9b5220efb901) serialization.json: 145 (804fec9f0738f88daef6d29b4c7075d7) 2025.07.28 06:15:32.847375 [ 2114 ] {2b02ed62-cc7e-4245-bded-21161da7740e} executeQuery: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56342) (comment: 02695_storage_join_insert_select_deadlock.sql) (query 4, line 11) (in query: INSERT INTO test_table_join SELECT * from test_table_join;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageJoin.cpp:329: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x000000001ab135f3 5. ./build_docker/./src/Storages/StorageSet.cpp:107: DB::SetOrJoinSink::consume(DB::Chunk&) @ 0x000000001adee243 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:32.890649 [ 2114 ] {} TCPHandler: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageJoin.cpp:329: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x000000001ab135f3 5. ./build_docker/./src/Storages/StorageSet.cpp:107: DB::SetOrJoinSink::consume(DB::Chunk&) @ 0x000000001adee243 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:15:32.922769 [ 2114 ] {6809dfca-7d03-4a94-91e1-4333c2a2551c} executeQuery: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56342) (comment: 02695_storage_join_insert_select_deadlock.sql) (query 5, line 13) (in query: INSERT INTO test_table_join SELECT * FROM (SELECT 1 as id) AS t1 ANY LEFT JOIN test_table_join USING (id);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageJoin.cpp:329: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x000000001ab135f3 5. ./build_docker/./src/Storages/StorageSet.cpp:107: DB::SetOrJoinSink::consume(DB::Chunk&) @ 0x000000001adee243 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:32.927692 [ 2114 ] {} TCPHandler: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageJoin.cpp:329: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x000000001ab135f3 5. ./build_docker/./src/Storages/StorageSet.cpp:107: DB::SetOrJoinSink::consume(DB::Chunk&) @ 0x000000001adee243 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:15:32.968612 [ 2114 ] {7e3bb815-097a-4679-bd88-06d06d29d559} executeQuery: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56342) (comment: 02695_storage_join_insert_select_deadlock.sql) (query 6, line 14) (in query: INSERT INTO test_table_join SELECT id, toString(id) FROM (SELECT 1 as id) AS t1 ANY LEFT JOIN (SELECT id FROM test_table_join) AS t2 USING (id);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageJoin.cpp:329: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x000000001ab135f3 5. ./build_docker/./src/Storages/StorageSet.cpp:107: DB::SetOrJoinSink::consume(DB::Chunk&) @ 0x000000001adee243 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:32.975519 [ 2114 ] {} TCPHandler: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageJoin.cpp:329: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x000000001ab135f3 5. ./build_docker/./src/Storages/StorageSet.cpp:107: DB::SetOrJoinSink::consume(DB::Chunk&) @ 0x000000001adee243 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:15:33.781355 [ 2114 ] {f5a463ed-7266-4f37-b679-fdb638809a45} executeQuery: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56360) (comment: 02304_grouping_sets_with_rollup_cube.sql) (query 1, line 1) (in query: SELECT number FROM numbers(10) GROUP BY GROUPING SETS ( number, number % 2 ) WITH ROLLUP;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5468: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a813ad 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:15:33.783148 [ 2114 ] {} TCPHandler: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5468: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a813ad 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:15:33.790858 [ 2114 ] {64a6d6b8-65e6-49d9-8b9d-a0238039ba7a} executeQuery: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56360) (comment: 02304_grouping_sets_with_rollup_cube.sql) (query 2, line 13) (in query: SELECT number FROM numbers(10) GROUP BY GROUPING SETS ( number, number % 2 ) WITH CUBE;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5468: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a813ad 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:15:33.791722 [ 2114 ] {} TCPHandler: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5468: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a813ad 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:15:33.803072 [ 16973 ] {694be56a-306b-4614-bfe1-da6bb4a4f7dd} executeQuery: Code: 117. DB::Exception: All arrays in column with vector similarity index must have equal length. (INCORRECT_DATA) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56356) (comment: 02354_vector_search_different_array_sizes.sql) (query 4, line 9) (in query: -- Vector similarity indexes reject INSERTs of Arrays with different sizes INSERT INTO tab values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexVectorSimilarity.cpp:278: DB::MergeTreeIndexAggregatorVectorSimilarity::update(DB::Block const&, unsigned long*, unsigned long) @ 0x000000001b4d9cd0 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:417: DB::MergeTreeDataPartWriterOnDisk::calculateAndSerializeSkipIndices(DB::Block const&, std::vector> const&) @ 0x000000001b41fc0d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:219: DB::MergeTreeDataPartWriterCompact::writeDataBlockPrimaryIndexAndSkipIndices(DB::Block const&, std::vector> const&) @ 0x000000001b413219 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:286: DB::MergeTreeDataPartWriterCompact::fillDataChecksums(DB::MergeTreeDataPartChecksums&) @ 0x000000001b414047 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:454: DB::MergeTreeDataPartWriterCompact::fillChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001b4151d7 9. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:213: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x000000001b60b672 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:784: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000001b46d6ca 11. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001b468732 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000001b80120c 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 20. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 21. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 22. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:15:33.804929 [ 16973 ] {} TCPHandler: Code: 117. DB::Exception: All arrays in column with vector similarity index must have equal length. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexVectorSimilarity.cpp:278: DB::MergeTreeIndexAggregatorVectorSimilarity::update(DB::Block const&, unsigned long*, unsigned long) @ 0x000000001b4d9cd0 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:417: DB::MergeTreeDataPartWriterOnDisk::calculateAndSerializeSkipIndices(DB::Block const&, std::vector> const&) @ 0x000000001b41fc0d 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:219: DB::MergeTreeDataPartWriterCompact::writeDataBlockPrimaryIndexAndSkipIndices(DB::Block const&, std::vector> const&) @ 0x000000001b413219 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:286: DB::MergeTreeDataPartWriterCompact::fillDataChecksums(DB::MergeTreeDataPartChecksums&) @ 0x000000001b414047 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:454: DB::MergeTreeDataPartWriterCompact::fillChecksums(DB::MergeTreeDataPartChecksums&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001b4151d7 9. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:213: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x000000001b60b672 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:784: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000001b46d6ca 11. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001b468732 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000001b80120c 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 20. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 21. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 22. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:15:34.066018 [ 16973 ] {5fe0cb6c-a6bd-4ef9-9aad-c8fd821da331} executeQuery: Code: 80. DB::Exception: The dimension of the reference vector in the query (2) does not match the dimension in the index (3). (INCORRECT_QUERY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56356) (comment: 02354_vector_search_different_array_sizes.sql) (query 8, line 17) (in query: WITH [0.0, 2.0] AS reference_vec SELECT id, vec, L2Distance(vec, reference_vec) FROM tab ORDER BY L2Distance(vec, reference_vec) LIMIT 3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x0000000010ac9c46 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexVectorSimilarity.cpp:430: DB::MergeTreeIndexConditionVectorSimilarity::calculateApproximateNearestNeighbors(std::shared_ptr) const @ 0x000000001b4dbe79 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1585: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x000000001b455c7a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:759: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool)::$_0::operator()(unsigned long) const @ 0x000000001b4515d8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:808: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000001b44d4eb 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b2441 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3bb568 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:15:34.067906 [ 16973 ] {} TCPHandler: Code: 80. DB::Exception: The dimension of the reference vector in the query (2) does not match the dimension in the index (3). (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x0000000010ac9c46 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexVectorSimilarity.cpp:430: DB::MergeTreeIndexConditionVectorSimilarity::calculateApproximateNearestNeighbors(std::shared_ptr) const @ 0x000000001b4dbe79 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1585: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x000000001b455c7a 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:759: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool)::$_0::operator()(unsigned long) const @ 0x000000001b4515d8 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:808: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000001b44d4eb 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b2441 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3bb568 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:15:35.428520 [ 1860 ] {7ef5fa0f-55ad-4440-9718-ad10c21bd5a6} executeQuery: Code: 36. DB::Exception: Setting max_bytes_ratio_before_external_group_by should be >= 0 and < 1 (-0.1). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56458) (comment: 03270_max_bytes_ratio_before_external_group_by.sql) (query 1, line 1) (in query: SELECT uniqExact(number::String) FROM numbers(10e6) GROUP BY (number%100)::String FORMAT Null SETTINGS max_bytes_ratio_before_external_group_by=-0.1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, double&) @ 0x000000000ee4eca0 4. ./build_docker/./src/Interpreters/Aggregator.cpp:239: DB::Aggregator::Params::getMaxBytesBeforeExternalGroupBy(unsigned long, double) @ 0x00000000183ac64b 5. ./build_docker/./src/Planner/Planner.cpp:446: DB::(anonymous namespace)::getAggregatorParams(std::shared_ptr const&, DB::AggregationAnalysisResult const&, DB::(anonymous namespace)::QueryAnalysisResult const&, DB::SelectQueryInfo const&, bool) @ 0x0000000018990728 6. ./build_docker/./src/Planner/Planner.cpp:483: DB::Planner::buildPlanForQueryNode() @ 0x000000001898792a 7. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:35.431438 [ 1860 ] {} TCPHandler: Code: 36. DB::Exception: Setting max_bytes_ratio_before_external_group_by should be >= 0 and < 1 (-0.1). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, double&) @ 0x000000000ee4eca0 4. ./build_docker/./src/Interpreters/Aggregator.cpp:239: DB::Aggregator::Params::getMaxBytesBeforeExternalGroupBy(unsigned long, double) @ 0x00000000183ac64b 5. ./build_docker/./src/Planner/Planner.cpp:446: DB::(anonymous namespace)::getAggregatorParams(std::shared_ptr const&, DB::AggregationAnalysisResult const&, DB::(anonymous namespace)::QueryAnalysisResult const&, DB::SelectQueryInfo const&, bool) @ 0x0000000018990728 6. ./build_docker/./src/Planner/Planner.cpp:483: DB::Planner::buildPlanForQueryNode() @ 0x000000001898792a 7. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:35.448429 [ 1860 ] {be36fe88-7a61-4752-82b0-f36fb8b2f9e1} executeQuery: Code: 36. DB::Exception: Setting max_bytes_ratio_before_external_group_by should be >= 0 and < 1 (1). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56458) (comment: 03270_max_bytes_ratio_before_external_group_by.sql) (query 2, line 2) (in query: SELECT uniqExact(number::String) FROM numbers(10e6) GROUP BY (number%100)::String FORMAT Null SETTINGS max_bytes_ratio_before_external_group_by=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, double&) @ 0x000000000ee4eca0 4. ./build_docker/./src/Interpreters/Aggregator.cpp:239: DB::Aggregator::Params::getMaxBytesBeforeExternalGroupBy(unsigned long, double) @ 0x00000000183ac64b 5. ./build_docker/./src/Planner/Planner.cpp:446: DB::(anonymous namespace)::getAggregatorParams(std::shared_ptr const&, DB::AggregationAnalysisResult const&, DB::(anonymous namespace)::QueryAnalysisResult const&, DB::SelectQueryInfo const&, bool) @ 0x0000000018990728 6. ./build_docker/./src/Planner/Planner.cpp:483: DB::Planner::buildPlanForQueryNode() @ 0x000000001898792a 7. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:35.450508 [ 1860 ] {} TCPHandler: Code: 36. DB::Exception: Setting max_bytes_ratio_before_external_group_by should be >= 0 and < 1 (1). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, double&) @ 0x000000000ee4eca0 4. ./build_docker/./src/Interpreters/Aggregator.cpp:239: DB::Aggregator::Params::getMaxBytesBeforeExternalGroupBy(unsigned long, double) @ 0x00000000183ac64b 5. ./build_docker/./src/Planner/Planner.cpp:446: DB::(anonymous namespace)::getAggregatorParams(std::shared_ptr const&, DB::AggregationAnalysisResult const&, DB::(anonymous namespace)::QueryAnalysisResult const&, DB::SelectQueryInfo const&, bool) @ 0x0000000018990728 6. ./build_docker/./src/Planner/Planner.cpp:483: DB::Planner::buildPlanForQueryNode() @ 0x000000001898792a 7. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:35.835929 [ 2054 ] {7e06e63c-b0f7-4eea-9bce-da4f11bcbce5} executeQuery: Code: 43. DB::Exception: Illegal types of arguments: Map(String, UInt8), UInt8 for function arrayElementOrNull. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56390) (comment: 03240_array_element_or_null.sql) (query 49, line 65) (in query: select arrayElementOrNull(m, 0), materialize(map('key', 42)) as m;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)1>::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001005da8f 5. DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000010054478 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 16. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:15:35.843902 [ 2054 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments: Map(String, UInt8), UInt8 for function arrayElementOrNull. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)1>::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001005da8f 5. DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000010054478 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 16. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:15:37.196719 [ 1855 ] {2ca55b2f-6f81-4f08-81a0-34168ed59ce0} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 53. DB::Exception: Automatically defined type String for column 'x' in row 1 differs from type defined by previous rows: Int64. You can specify the type for this column using setting schema_inference_hints. (TYPE_MISMATCH) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38868) (comment: 02497_schema_inference_nulls.sql) (query 7, line 7) (in query: desc format(JSONEachRow, '{"x" : 1234}, {"x" : "String"}') settings input_format_json_try_infer_numbers_from_strings=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbd0d6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013d046e4 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018e883a0 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000018e8713e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:37.197864 [ 1855 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 53. DB::Exception: Automatically defined type String for column 'x' in row 1 differs from type defined by previous rows: Int64. You can specify the type for this column using setting schema_inference_hints. (TYPE_MISMATCH) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbd0d6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013d046e4 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018e883a0 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000018e8713e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:37.493174 [ 1855 ] {e59da00c-1a59-473f-ac19-780c7294ee6b} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 53. DB::Exception: Automatically defined type String for column '1' in row 1 differs from type defined by previous rows: Int64. You can specify the type for this column using setting schema_inference_hints. (TYPE_MISMATCH) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38868) (comment: 02497_schema_inference_nulls.sql) (query 27, line 29) (in query: desc format(JSONCompactEachRow, '[1234], ["String"]') settings input_format_json_try_infer_numbers_from_strings=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbd0d6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013d046e4 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018e883a0 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000018e8713e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:37.494448 [ 1855 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 53. DB::Exception: Automatically defined type String for column '1' in row 1 differs from type defined by previous rows: Int64. You can specify the type for this column using setting schema_inference_hints. (TYPE_MISMATCH) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbd0d6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013d046e4 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018e883a0 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000018e8713e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:41.043544 [ 16819 ] {193ac1cb-27f2-49c4-9305-067f3c7d9853} executeQuery: Code: 162. DB::Exception: Too deep subqueries. Maximum: 1. (TOO_DEEP_SUBQUERIES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39046) (comment: 02379_analyzer_subquery_depth.sql) (query 2, line 3) (in query: SELECT (SELECT a FROM (SELECT 1 AS a)) SETTINGS max_subquery_depth = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a0fa460 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5446: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a81329 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a86fde 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc6d9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a86fde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:15:41.045036 [ 16819 ] {} TCPHandler: Code: 162. DB::Exception: Too deep subqueries. Maximum: 1. (TOO_DEEP_SUBQUERIES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a0fa460 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5446: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a81329 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a86fde 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc6d9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a86fde 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:15:45.562006 [ 16973 ] {c8111bf2-88d0-4a4b-a478-e3a56c58558b} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39448) (comment: 02416_json_object_inference.sql) (query 4, line 5) (in query: desc format(JSONEachRow, '{"a" : {"b" : {"c" : 1, "d" : "str"}}}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbcdce 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013d046e4 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018e883a0 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000018e8713e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:45.563556 [ 16973 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbcdce 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013d046e4 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018e883a0 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000018e8713e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:15:52.869205 [ 16973 ] {894da7a9-9830-4124-94c4-51e5d88c18f8} executeQuery: Code: 344. DB::Exception: Only support CLONE AS from tables of the MergeTree family. (SUPPORT_IS_DISABLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37300) (comment: 03231_create_with_clone_as.sql) (query 20, line 26) (in query: CREATE TABLE clone_as_foo_memory CLONE AS foo_memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:875: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188bb3fc 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:52.870946 [ 16973 ] {} TCPHandler: Code: 344. DB::Exception: Only support CLONE AS from tables of the MergeTree family. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:875: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188bb3fc 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:52.921481 [ 16973 ] {a7909d6c-71ef-4562-b59c-cac0b8d600a5} executeQuery: Code: 344. DB::Exception: Only support CLONE AS from tables of the MergeTree family. (SUPPORT_IS_DISABLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37300) (comment: 03231_create_with_clone_as.sql) (query 24, line 33) (in query: CREATE TABLE clone_as_foo_file CLONE AS foo_file;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:875: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188bb3fc 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:52.922809 [ 16973 ] {} TCPHandler: Code: 344. DB::Exception: Only support CLONE AS from tables of the MergeTree family. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:875: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188bb3fc 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:53.230112 [ 16973 ] {89b99dad-b785-43ca-b4ab-327a60c9f5b7} executeQuery: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37300) (comment: 03231_create_with_clone_as.sql) (query 38, line 52) (in query: CREATE TABLE clone_as_foo_merge_tree_p_y CLONE AS foo_merge_tree ENGINE=MergeTree PRIMARY KEY y;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:905: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188bb376 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:53.231161 [ 16973 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:905: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188bb376 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:53.417573 [ 2095 ] {386353a0-4da6-424e-903f-11199b4fa3ee} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT intDiv(-1, 0). (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37346) (comment: 00977_int_div.sql) (query 16, line 31) (in query: SELECT -1 DIV 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. _ZN2DB25throwIfDivisionLeadsToFPEIDB8_S1_EEvT_T0_ @ 0x000000000ac71f11 5. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bcc448f 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bcc251a 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc6bd2b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc66e33 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc65846 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc6447e 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:15:53.419459 [ 2095 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT intDiv(-1, 0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. _ZN2DB25throwIfDivisionLeadsToFPEIDB8_S1_EEvT_T0_ @ 0x000000000ac71f11 5. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bcc448f 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bcc251a 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc6bd2b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc66e33 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc65846 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc6447e 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:15:53.476309 [ 16973 ] {64e2ea11-afe0-477e-9315-c73d1ea2bbbe} executeQuery: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37300) (comment: 03231_create_with_clone_as.sql) (query 52, line 71) (in query: CREATE TABLE clone_as_foo_replacing_merge_tree_p_y CLONE AS foo_replacing_merge_tree ENGINE=ReplacingMergeTree PRIMARY KEY y;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:905: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188bb376 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:53.477308 [ 16973 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:905: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188bb376 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:53.890385 [ 16973 ] {df4dc731-56b1-44e7-92ab-b64b4643817f} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/test_6gcev4zr/test_foo_replicated_merge_tree/replicas/r1 already exists. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37300) (comment: 03231_create_with_clone_as.sql) (query 58, line 80) (in query: CREATE TABLE clone_as_foo_replicated_merge_tree CLONE AS foo_replicated_merge_tree;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001ac5bb34 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x000000001ac36e2d 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x000000001ac32d1f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001b7ae651 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa4be 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:15:53.892159 [ 16973 ] {} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/test_6gcev4zr/test_foo_replicated_merge_tree/replicas/r1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001ac5bb34 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x000000001ac36e2d 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x000000001ac32d1f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001b7ae651 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa4be 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:15:54.059028 [ 16973 ] {198be8be-87fe-4860-bc4f-c41c53cae067} executeQuery: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37300) (comment: 03231_create_with_clone_as.sql) (query 63, line 87) (in query: CREATE TABLE clone_as_foo_replicated_merge_tree_p_y CLONE AS foo_replicated_merge_tree ENGINE=ReplicatedMergeTree('/clickhouse/tables/{database}/clone_as_foo_replicated_merge_tree_p_y', 'r1') PRIMARY KEY y;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:905: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188bb376 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:54.060520 [ 16973 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:905: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188bb376 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:15:54.922231 [ 16973 ] {c3bad98b-3bd1-4e36-b2df-2f1c81bc2c35} executeQuery: Code: 344. DB::Exception: CREATE CLONE AS is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37300) (comment: 03231_create_with_clone_as.sql) (query 88, line 117) (in query: CREATE TABLE clone_as_foo_merge_tree CLONE AS foo_merge_tree;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1712: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c673e 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:15:54.923660 [ 16973 ] {} TCPHandler: Code: 344. DB::Exception: CREATE CLONE AS is not supported with Replicated databases. Consider using separate CREATE and INSERT queries. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1712: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c673e 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:16:01.533020 [ 1865 ] {alter_00816_2} test_a60a9ct3.concurrent_alter_column (3120759b-8585-4778-87b5-c8d68b0e2a29): Failed to alter table in database, reverting changes 2025.07.28 06:16:02.087393 [ 1865 ] {alter_00816_2} executeQuery: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/store/b38/b3803656-47d3-466b-8bb5-f48e00b78b83/concurrent_alter_column.sql: , errno: 2, strerror: No such file or directory. (FILE_DOESNT_EXIST) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42960) (comment: 00816_long_concurrent_alter_column.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_column DROP COLUMN d ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&) @ 0x0000000010c227a5 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x0000000010c2239d 5. ./build_docker/./src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x0000000010c2b828 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x000000001648f95c 7. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000001648f618 8. ./build_docker/./src/Disks/DiskLocal.cpp:343: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x0000000017862f93 9. ./build_docker/./src/Databases/DatabasesCommon.cpp:308: DB::readMetadataFile(std::shared_ptr, String const&) @ 0x000000001770ed23 10. ./build_docker/./src/Databases/DatabaseOrdinary.cpp:599: DB::DatabaseOrdinary::alterTable(std::shared_ptr, DB::StorageID const&, DB::StorageInMemoryMetadata const&) @ 0x00000000176a43c4 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:441: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001b7b47e3 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:16:02.101872 [ 1865 ] {alter_00816_2} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:42960). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d883af 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2558: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000001bbe8f95 7. ./build_docker/./src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x000000001bbdaef1 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:02.102243 [ 1865 ] {} TCPHandler: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/store/b38/b3803656-47d3-466b-8bb5-f48e00b78b83/concurrent_alter_column.sql: , errno: 2, strerror: No such file or directory. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&) @ 0x0000000010c227a5 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x0000000010c2239d 5. ./build_docker/./src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x0000000010c2b828 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x000000001648f95c 7. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000001648f618 8. ./build_docker/./src/Disks/DiskLocal.cpp:343: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x0000000017862f93 9. ./build_docker/./src/Databases/DatabasesCommon.cpp:308: DB::readMetadataFile(std::shared_ptr, String const&) @ 0x000000001770ed23 10. ./build_docker/./src/Databases/DatabaseOrdinary.cpp:599: DB::DatabaseOrdinary::alterTable(std::shared_ptr, DB::StorageID const&, DB::StorageInMemoryMetadata const&) @ 0x00000000176a43c4 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:441: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001b7b47e3 12. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:16:05.135717 [ 2054 ] {f31922b1-13e7-441a-946b-89f3d5fe462c} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: JSONLength('^?V{LSwp'): In scope SELECT JSONExtractKeysAndValues([], JSONLength('^?V{LSwp')). (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43066) (comment: 00918_json_functions.sql) (query 159, line 179) (in query: SELECT JSONExtractKeysAndValues([], JSONLength('^?V{LSwp'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. DB::JSONExtractKeysAndValuesImpl::getReturnType(char const*, std::vector> const&) @ 0x000000000907f061 5. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x000000000907e1aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:16:05.137437 [ 2054 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: JSONLength('^?V{LSwp'): In scope SELECT JSONExtractKeysAndValues([], JSONLength('^?V{LSwp')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. DB::JSONExtractKeysAndValuesImpl::getReturnType(char const*, std::vector> const&) @ 0x000000000907f061 5. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x000000000907e1aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:16:05.261346 [ 2054 ] {2c1442a0-73b5-4e90-9bca-43066c1de7fa} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: JSONType(json, 'i'): In scope WITH '{"i": 1, "f": 1.2}' AS json SELECT JSONExtract(json, 'i', JSONType(json, 'i')). (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43066) (comment: 00918_json_functions.sql) (query 160, line 180) (in query: WITH '{"i": 1, "f": 1.2}' AS json SELECT JSONExtract(json, 'i', JSONType(json, 'i'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. DB::JSONExtractImpl::getReturnType(char const*, std::vector> const&) @ 0x000000000907a243 5. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x00000000090798aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:16:05.262218 [ 2054 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: JSONType(json, 'i'): In scope WITH '{"i": 1, "f": 1.2}' AS json SELECT JSONExtract(json, 'i', JSONType(json, 'i')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. DB::JSONExtractImpl::getReturnType(char const*, std::vector> const&) @ 0x000000000907a243 5. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x00000000090798aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:16:05.412000 [ 2054 ] {8c755c21-16c8-4d92-be46-ee19eba689bd} executeQuery: Code: 43. DB::Exception: JSONExtract doesn't support the return type schema: Map(Int64, Array(Float64)) with key type not String: In scope SELECT JSONExtract('{"a": [100.0, 200], "b": [-100, 200.0, 300]}', 'Map(Int64, Array(Float64))'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43066) (comment: 00918_json_functions.sql) (query 162, line 183) (in query: SELECT JSONExtract('{"a": [100.0, 200], "b": [-100, 200.0, 300]}', 'Map(Int64, Array(Float64))');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&, String&&) @ 0x000000001415f826 4. ./build_docker/./src/Formats/JSONExtractTree.cpp:1946: std::unique_ptr, std::default_delete>> DB::buildJSONExtractTree(std::shared_ptr const&, char const*) @ 0x000000001bc852ce 5. DB::FunctionJSONHelpers::Executor::run(std::vector> const&, std::shared_ptr const&, unsigned long, DB::FormatSettings const&) @ 0x000000000907c088 6. DB::ExecutableFunctionJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000907b897 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:16:05.413404 [ 2054 ] {} TCPHandler: Code: 43. DB::Exception: JSONExtract doesn't support the return type schema: Map(Int64, Array(Float64)) with key type not String: In scope SELECT JSONExtract('{"a": [100.0, 200], "b": [-100, 200.0, 300]}', 'Map(Int64, Array(Float64))'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&, String&&) @ 0x000000001415f826 4. ./build_docker/./src/Formats/JSONExtractTree.cpp:1946: std::unique_ptr, std::default_delete>> DB::buildJSONExtractTree(std::shared_ptr const&, char const*) @ 0x000000001bc852ce 5. DB::FunctionJSONHelpers::Executor::run(std::vector> const&, std::shared_ptr const&, unsigned long, DB::FormatSettings const&) @ 0x000000000907c088 6. DB::ExecutableFunctionJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000907b897 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:16:05.559434 [ 24373 ] {30d0ade8-bacb-4d09-b01f-7e898f6780cd} executeQuery: Code: 47. DB::Exception: Unknown expression or table expression identifier `t1_02867` in scope SELECT count() AS a FROM numbers(10) WHERE number IN (t1_02867). (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43870) (comment: 02867_storage_set_tsan.sh) (query 1, line 1) (in query: SELECT count() as a FROM numbers(10) WHERE number IN t1_02867), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5630: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7f0b0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:05.561129 [ 24373 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or table expression identifier `t1_02867` in scope SELECT count() AS a FROM numbers(10) WHERE number IN (t1_02867). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5630: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7f0b0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:05.929840 [ 24367 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_lpu7tmui does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:532: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000182cf4e5 5. ./build_docker/./src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x000000001bbd90f7 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:05.930260 [ 24367 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_lpu7tmui does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:532: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000182cf4e5 5. ./build_docker/./src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x000000001bbd90f7 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:05.948853 [ 24373 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_lpu7tmui does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:532: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000182cf4e5 5. ./build_docker/./src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x000000001bbd90f7 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:05.949049 [ 24373 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_lpu7tmui does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:532: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000182cf4e5 5. ./build_docker/./src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x000000001bbd90f7 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:06.003843 [ 24373 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_lpu7tmui does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:532: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000182cf4e5 5. ./build_docker/./src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x000000001bbd90f7 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:06.004084 [ 24373 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_lpu7tmui does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:532: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000182cf4e5 5. ./build_docker/./src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x000000001bbd90f7 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:06.149744 [ 1860 ] {de635512-44b2-4f6e-8a5d-3dce384efe6f} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43932) (comment: 01132_max_rows_to_read.sql) (query 4, line 5) (in query: SELECT count() FROM numbers(30);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001c451086 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001c44fff7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c44ea73 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:16:06.150784 [ 1860 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001c451086 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001c44fff7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c44ea73 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:16:06.271262 [ 1860 ] {e9f48fb8-dfaf-4c00-a72b-aada4c6ae244} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 21.00. (TOO_MANY_ROWS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43932) (comment: 01132_max_rows_to_read.sql) (query 7, line 8) (in query: SELECT count() FROM numbers(21);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001c451086 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001c44fff7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c44ea73 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:16:06.272811 [ 1860 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 21.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001c451086 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001c44fff7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c44ea73 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:16:06.282672 [ 1860 ] {b313850f-1ee3-4de4-a2e9-2502d61b773f} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43932) (comment: 01132_max_rows_to_read.sql) (query 8, line 10) (in query: -- check early exception if the estimated number of rows is high SELECT * FROM numbers(30);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001c451086 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001c44fff7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c44ea73 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:16:06.283798 [ 1860 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001c451086 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001c44fff7 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c44ea73 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:16:06.406875 [ 24373 ] {cb96409b-c512-4052-a01d-fd563e6528c8} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (106.667, 10.7674); method: t; operations: x/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 4}/{0, -1, -1, 0}: In scope SELECT pointInPolygon((106.677085876465, 10.7744951248169), [(106.667161868227, 10.7675128359024), (106.667165727127, 10.7675059912261), (106.667170817563, 10.7674904752629), (106.667229225265, 10.7672278502066), (106.667231193621, 10.7672115129572), (106.667229912029, 10.7671951075415), (106.667225430503, 10.767179274157), (106.667217923927, 10.7671646306786), (106.667207685234, 10.7671517485471), (106.667195113975, 10.7671411304688), (106.667180700725, 10.7671331907989), (106.66716500794, 10.7671282393715), (106.666628232995, 10.7670156787539), (106.666612233649, 10.7670139127584), (106.666596193354, 10.7670152569112), (106.666580711053, 10.7670196610218), (106.666566364856, 10.7670269606408), (106.666553690448, 10.7670368832008), (106.666543161092, 10.767049058194), (106.666535169952, 10.7670630310067), (106.666530015418, 10.7670782798948), (106.666482284259, 10.7672828714379), (106.666480170141, 10.7672985245675), (106.666481048788, 10.7673142953614), (106.666484888609, 10.7673296167758), (106.666491551541, 10.7673439379244), (106.666500798017, 10.7673567438858), (106.666512295576, 10.7673675742178), (106.666525630821, 10.7673760395122), (106.667032331859, 10.7676338521733), (106.6671413386, 10.7676893154858), (106.667371048786, 10.7678061934666), (106.667552760053, 10.7678987010209), (106.667801848625, 10.7680278028917), (106.667817742281, 10.7680340673957), (106.667834579682, 10.7680369577679), (106.66785165264, 10.7680363524383), (106.667868243061, 10.7680322768672), (106.667878683314, 10.7680285412847), (106.667885469819, 10.7680268413536), (106.667892390269, 10.7680258148018), (106.667899378015, 10.7680254715159), (106.667906365761, 10.7680258148018), (106.667913286211, 10.7680268413536), (106.667920072716, 10.7680285412847), (106.667926659921, 10.7680308982244), (106.667932984386, 10.7680338894736), (106.667938985204, 10.7680374862253), (106.667944604583, 10.7680416538412), (106.667949788405, 10.7680463521828), (106.667954486747, 10.7680515360051), (106.667958654362, 10.7680571553826), (106.667962251113, 10.7680631561994), (106.667965242363, 10.7680694806664), (106.667967599303, 10.7680760678724), (106.667969299234, 10.7680828543774), (106.667970926246, 10.7680938227996), (106.667974657027, 10.7681089916695), (106.667981154238, 10.7681231972879), (106.667990189396, 10.7681359400994), (106.668001444773, 10.7681467719897), (106.668014524559, 10.7681553120441), (106.668198488147, 10.7682521458591), (106.669562015793, 10.7689901124345), (106.669614757162, 10.7690820717448), (106.669623023723, 10.7690939566151), (106.669633223154, 10.7691042307472), (106.669645047385, 10.7691125838155), (106.670748051536, 10.7697559307954), (106.670751419717, 10.7697577924329), (106.671035494073, 10.7699063431327), (106.671270162713, 10.7700364834325), (106.67127192876, 10.7700374352053), (106.671437929267, 10.7701243344783), (106.671665917937, 10.7702517637461), (106.67166656035, 10.7702521191025), (106.671943689514, 10.7704038245574), (106.671943806749, 10.7704038886117), (106.6722776446, 10.7705859421916), (106.672278295949, 10.7705862936499), (106.673020324076, 10.7709824352208), (106.673433726727, 10.7712057751884), (106.673694081332, 10.7713489702214), (106.673977066657, 10.7715146655761), (106.674254247937, 10.7716778144336), (106.67440928634, 10.7717698954974), (106.674658478275, 10.7719268836667), (106.674658802254, 10.7719270867325), (106.6748919449, 10.7720724734391), (106.675071660589, 10.7721853602936), (106.675350447469, 10.7723606751059), (106.675350748696, 10.7723608636368), (106.6756252856, 10.7725318758852), (106.675888735092, 10.7726957126602), (106.676114500069, 10.7728361211927), (106.676379504941, 10.7730007692002), (106.67661713771, 10.7731502653527), (106.676617572241, 10.773150536857), (106.676852995814, 10.7732966297465), (106.677284352687, 10.7735807849214), (106.677738143311, 10.7738851794554), (106.677752655777, 10.7738929549383), (106.677768414072, 10.773897724206), (106.677784802596, 10.7738993009456), (106.677801181124, 10.7738976235612), (106.677816909825, 10.7738927575805), (106.677831374252, 10.7738848930944), (106.677844009349, 10.7738743373313), (106.677920079221, 10.7737967983562), (106.678239245717, 10.7735243703649), (106.67839926068, 10.7733892116467), (106.678400691571, 10.7733879749217), (106.678515896101, 10.7732860955802), (106.678557979259, 10.7732504310319), (106.67855930664, 10.7732492818517), (106.679033975331, 10.7728295048433), (106.679053201911, 10.772844898411), (106.679632133733, 10.7733262832973), (106.679771732358, 10.7734524450384), (106.679773325229, 10.7734538481348), (106.680011463819, 10.7736582857586), (106.680175801881, 10.7738018862846), (106.680176891116, 10.7738028216402), (106.680320149367, 10.773923712053), (106.680672123374, 10.7742204563391), (106.68094213423, 10.7744504786771), (106.68094233625, 10.7744506502241), (106.68124725775, 10.7747087432576), (106.681247329066, 10.7747088035527), (106.681470746982, 10.7748974804345), (106.681471338135, 10.7748979749973), (106.681840030697, 10.7752035373868), (106.682304929691, 10.7756040772245), (106.682308650112, 10.7756071005185), (106.682312917236, 10.7756103687835), (106.682359764439, 10.7756490693986), (106.682640114944, 10.7758996628849), (106.682644070655, 10.7759029839554), (106.682711710544, 10.7759562859055), (106.682806505954, 10.7760368956153), (106.68280745353, 10.776037689352), (106.683169164535, 10.7763361378178), (106.68363265876, 10.7767252395911), (106.683677875719, 10.7767650291442), (106.683797775698, 10.77688614766), (106.684138558845, 10.7772306328105), (106.68414063031, 10.7772326552454), (106.684827531639, 10.777880369263), (106.685228619785, 10.7782605077038), (106.685228896163, 10.7782607684525), (106.686025996525, 10.7790093622583), (106.686026813787, 10.7790101368229), (106.68658269265, 10.7795369738106), (106.687194479537, 10.7801158277128), (106.688401155505, 10.7812670656457), (106.688401571342, 10.7812674596561), (106.689622367701, 10.7824162362891), (106.690002723257, 10.7827815572149), (106.690002908997, 10.7827817350625), (106.690359062158, 10.7831217027417), (106.690359638585, 10.7831222477508), (106.690747557266, 10.7834855403784), (106.691628272565, 10.7843952548301), (106.692179613338, 10.7849709155958), (106.692179802225, 10.7849711121697), (106.692743910048, 10.7855562574979), (106.693288875836, 10.7861225208133), (106.693601234729, 10.7864484801726), (106.69220838651, 10.7875617536129), (106.692196691453, 10.787573150248), (106.692187444486, 10.7875866094924), (106.692181000965, 10.7876016141149), (106.692177608512, 10.7876175874962), (106.692177397496, 10.7876339157883), (106.692180376026, 10.7876499715041), (106.692186429639, 10.7876651376314), (106.692195325699, 10.7876788313445), (106.692206722334, 10.7876905264015), (106.692220181578, 10.7876997733682), (106.692235186201, 10.7877062168886), (106.692251159582, 10.787709609342), (106.692267487874, 10.7877098203582), (106.69228354359, 10.7877068418281), (106.692298709717, 10.7877007882148), (106.69231240343, 10.7876918921553), (106.693776442708, 10.7865217172423), (106.693788736175, 10.7865096022178), (106.693798269005, 10.7864952137411), (106.693804631934, 10.7864791695437), (106.693807551784, 10.7864621584413), (106.693806903199, 10.7864449107613), (106.693802714026, 10.7864281669878), (106.693795164114, 10.786412645971), (106.693784577601, 10.7863990140651), (106.69340910087, 10.7860071886444), (106.69340897739, 10.7860070600637), (106.692863924954, 10.7854407067139), (106.69229983717, 10.7848555821281), (106.691748435669, 10.7842798579551), (106.691748124777, 10.7842795350934), (106.690865834778, 10.7833681940925), (106.690862927107, 10.7833653342196), (106.690473809086, 10.7830009183885), (106.690118035849, 10.7826613133679), (106.689737465891, 10.7822957865149), (106.689736848623, 10.7822951996834), (106.688515950726, 10.7811463275029), (106.687309357068, 10.7799951680976), (106.687309106711, 10.779994930232), (106.686697270266, 10.7794160294802), (106.686141416688, 10.7788892164565), (106.686140461741, 10.7788883114), (106.686140185762, 10.7788880510296), (106.6853430856, 10.7781394574112), (106.684942058447, 10.7777593767781), (106.684941904463, 10.7777592312084), (106.684255979358, 10.7771124377212), (106.683916204215, 10.776768971525), (106.683794256559, 10.7766457845149), (106.68379008676, 10.7766418525893), (106.683741989497, 10.7765995284558), (106.683740519326, 10.7765982647987), (106.683276011394, 10.7762083120217), (106.683275466929, 10.7762078588774), (106.68291395946, 10.77590957835), (106.682818451152, 10.775828362424), (106.682816046951, 10.7758263940715), (106.682749215964, 10.7757737295564), (106.682469581984, 10.775523776542), (106.682467121137, 10.7755216616573), (106.682417839663, 10.775480950083), (106.68241543796, 10.7754790393628), (106.682411856108, 10.7754762959601), (106.681948170223, 10.775076801292), (106.681946953215, 10.7750757728772), (106.681577943952, 10.7747699480145), (106.681354856141, 10.7745815499075), (106.681050071432, 10.7743235726569), (106.680779998801, 10.774093497693), (106.680779672798, 10.7740932214111), (106.680427578845, 10.7737963760106), (106.680284883706, 10.7736759607876), (106.680120811518, 10.7735325925854), (106.680120259999, 10.7735321149047), (106.679882649978, 10.7733281310479), (106.679742564868, 10.7732015296478), (106.67973997054, 10.7731992804165), (106.679159125009, 10.772716304271), (106.679157929246, 10.7727153285815), (106.679083371982, 10.7726556350576), (106.679069423592, 10.7726465921904), (106.679053957365, 10.7726404990091), (106.679037589221, 10.7726375981655), (106.679020970997, 10.7726380051815), (106.679004764489, 10.7726417038483), (106.678989615098, 10.7726485468719), (106.678976126125, 10.772658261739), (106.678449597495, 10.7731239014943), (106.678407514754, 10.773159565689), (106.678406188192, 10.7731607141448), (106.678291034854, 10.7732625482153), (106.678131577851, 10.7733972356454), (106.678131249559, 10.7733975143985), (106.677809116892, 10.7736724741964), (106.677803734254, 10.7736774962862), (106.67777351642, 10.773708297704), (106.677376870851, 10.7734422350384), (106.677376291861, 10.7734418501559), (106.676943701895, 10.7731568826838), (106.676941799819, 10.7731556663352), (106.676705634648, 10.7730091132449), (106.676468020922, 10.7728596290723), (106.676467624617, 10.7728593813034), (106.676202468827, 10.7726946395397), (106.675976718772, 10.7725542402878), (106.675713344944, 10.7723904505946), (106.675438984881, 10.7722195485022), (106.675160330528, 10.7720443170291), (106.674980445983, 10.7719313240966), (106.674980215342, 10.7719311797465), (106.674747119479, 10.7717858222138), (106.674497164595, 10.7716283533947), (106.674495300219, 10.7716272127471), (106.674339180867, 10.7715344896819), (106.674338897981, 10.771534322423), (106.674061493048, 10.7713710419232), (106.674061328848, 10.7713709455279), (106.673777295695, 10.7712046366425), (106.673775349509, 10.7712035319333), (106.673513740027, 10.7710596467179), (106.673513190173, 10.7710593469847), (106.673099330442, 10.7708357600807), (106.673098966779, 10.7708355647753), (106.672357083034, 10.7704395002842), (106.672023628724, 10.7702576558632), (106.671746880137, 10.7701061587426), (106.671518215262, 10.7699783515251), (106.671516207112, 10.7699772649622), (106.671350083838, 10.7698903014222), (106.671115399209, 10.7697601522552), (106.671113600766, 10.7697591835329), (106.670830326847, 10.7696110514048), (106.66974820551, 10.7689798847013), (106.66969475177, 10.7688866833063), (106.669685913661, 10.7688741199651), (106.669674918986, 10.7688633930448), (106.669662141606, 10.7688548673033), (106.668277363011, 10.7681053993183), (106.668276514094, 10.7681049461882), (106.668126503268, 10.7680259842551), (106.668125839186, 10.7680237950692), (106.66812072496, 10.7680095017658), (106.668117596648, 10.7680019493532), (106.66811110606, 10.7679882261576), (106.668107252546, 10.7679810167398), (106.668099448104, 10.7679679958141), (106.668094906497, 10.767961198818), (106.668085863361, 10.7679490055608), (106.668080677403, 10.7679426864524), (106.668070482664, 10.7679314382913), (106.668064702296, 10.7679256579236), (106.668053454135, 10.7679154631847), (106.668047135024, 10.7679102772246), (106.668034941766, 10.7679012340887), (106.668028144776, 10.7678966924853), (106.668015123851, 10.7678888880428), (106.668007914429, 10.7678850345264), (106.667994191233, 10.7678785439383), (106.667986638821, 10.7678754156266), (106.667972345518, 10.7678703014008), (106.667964522841, 10.7678679284177), (106.667949797082, 10.7678642398071), (106.667941779481, 10.7678626450072), (106.667926763083, 10.767860417535), (106.667918627772, 10.7678596162768), (106.667903465352, 10.7678588713949), (106.667895290678, 10.7678588713949), (106.667880128258, 10.7678596162768), (106.667871992947, 10.767860417535), (106.667856976549, 10.7678626450072), (106.667848958948, 10.7678642398071), (106.667848526162, 10.7678643482145), (106.667629153721, 10.7677506481269), (106.667628614008, 10.7677503708842), (106.66744662399, 10.7676577214203), (106.667216888626, 10.7675408306262), (106.667161868227, 10.7675128359024), (106.667012119458, 10.7674366427911), (106.666659357657, 10.7672571553777), (106.666673753979, 10.7671954479766), (106.667048293768, 10.7672739882109), (106.667012119458, 10.7674366427911)]). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43958) (comment: 00500_point_in_polygon_bug_3_linestring_rotation_precision.sql) (query 2, line 3) (in query: SELECT pointInPolygon((106.677085876465,10.7744951248169), [(106.667161868227,10.7675128359024),(106.667165727127,10.7675059912261),(106.667170817563,10.7674904752629),(106.667229225265,10.7672278502066),(106.667231193621,10.7672115129572),(106.667229912029,10.7671951075415),(106.667225430503,10.767179274157),(106.667217923927,10.7671646306786),(106.667207685234,10.7671517485471),(106.667195113975,10.7671411304688),(106.667180700725,10.7671331907989),(106.66716500794,10.7671282393715),(106.666628232995,10.7670156787539),(106.666612233649,10.7670139127584),(106.666596193354,10.7670152569112),(106.666580711053,10.7670196610218),(106.666566364856,10.7670269606408),(106.666553690448,10.7670368832008),(106.666543161092,10.767049058194),(106.666535169952,10.7670630310067),(106.666530015418,10.7670782798948),(106.666482284259,10.7672828714379),(106.666480170141,10.7672985245675),(106.666481048788,10.7673142953614),(106.666484888609,10.7673296167758),(106.666491551541,10.7673439379244),(106.666500798017,10.7673567438858),(106.666512295576,10.7673675742178),(106.666525630821,10.7673760395122),(106.667032331859,10.7676338521733),(106.6671413386,10.7676893154858),(106.667371048786,10.7678061934666),(106.667552760053,10.7678987010209),(106.667801848625,10.7680278028917),(106.667817742281,10.7680340673957),(106.667834579682,10.7680369577679),(106.66785165264,10.7680363524383),(106.667868243061,10.7680322768672),(106.667878683314,10.7680285412847),(106.667885469819,10.7680268413536),(106.667892390269,10.7680258148018),(106.667899378015,10.7680254715159),(106.667906365761,10.7680258148018),(106.667913286211,10.7680268413536),(106.667920072716,10.7680285412847),(106.667926659921,10.7680308982244),(106.667932984386,10.7680338894736),(106.667938985204,10.7680374862253),(106.667944604583,10.7680416538412),(106.667949788405,10.7680463521828),(106.667954486747,10.7680515360051),(106.667958654362,10.7680571553826),(106.667962251113,10.7680631561994),(106.667965242363,10.7680694806664),(106.667967599303,10.7680760678724),(106.667969299234,10.7680828543774),(106.667970926246,10.7680938227996),(106.667974657027,10.7681089916695),(106.667981154238,10.7681231972879),(106.667990189396,10.7681359400994),(106.668001444773,10.7681467719897),(106.668014524559,10.7681553120441),(106.668198488147,10.7682521458591),(106.669562015793,10.7689901124345),(106.669614757162,10.7690820717448),(106.669623023723,10.7690939566151),(106.669633223154,10.7691042307472),(106.669645047385,10.7691125838155),(106.670748051536,10.7697559307954),(106.670751419717,10.7697577924329),(106.671035494073,10.7699063431327),(106.671270162713,10.7700364834325),(106.67127192876,10.7700374352053),(106.671437929267,10.7701243344783),(106.671665917937,10.7702517637461),(106.67166656035,10.7702521191025),(106.671943689514,10.7704038245574),(106.671943806749,10.7704038886117),(106.6722776446,10.7705859421916),(106.672278295949,10.7705862936499),(106.673020324076,10.7709824352208),(106.673433726727,10.7712057751884),(106.673694081332,10.7713489702214),(106.673977066657,10.7715146655761),(106.674254247937,10.7716778144336),(106.67440928634,10.7717698954974),(106.674658478275,10.7719268836667),(106.674658802254,10.7719270867325),(106.6748919449,10.7720724734391),(106.675071660589,10.7721853602936),(106.675350447469,10.7723606751059),(106.675350748696,10.7723608636368),(106.6756252856,10.7725318758852),(106.675888735092,10.7726957126602),(106.676114500069,10.7728361211927),(106.676379504941,10.7730007692002),(106.67661713771,10.7731502653527),(106.676617572241,10.773150536857),(106.676852995814,10.7732966297465),(106.677284352687,10.7735807849214),(106.677738143311,10.7738851794554),(106.677752655777,10.7738929549383),(106.677768414072,10.773897724206),(106.677784802596,10.7738993009456),(106.677801181124,10.7738976235612),(106.677816909825,10.7738927575805),(106.677831374252,10.7738848930944),(106.677844009349,10.7738743373313),(106.677920079221,10.7737967983562),(106.678239245717,10.7735243703649),(106.67839926068,10.7733892116467),(106.678400691571,10.7733879749217),(106.678515896101,10.7732860955802),(106.678557979259,10.7732504310319),(106.67855930664,10.7732492818517),(106.679033975331,10.7728295048433),(106.679053201911,10.772844898411),(106.679632133733,10.7733262832973),(106.679771732358,10.7734524450384),(106.679773325229,10.7734538481348),(106.680011463819,10.7736582857586),(106.680175801881,10.7738018862846),(106.680176891116,10.7738028216402),(106.680320149367,10.773923712053),(106.680672123374,10.7742204563391),(106.68094213423,10.7744504786771),(106.68094233625,10.7744506502241),(106.68124725775,10.7747087432576),(106.681247329066,10.7747088035527),(106.681470746982,10.7748974804345),(106.681471338135,10.7748979749973),(106.681840030697,10.7752035373868),(106.682304929691,10.7756040772245),(106.682308650112,10.7756071005185),(106.682312917236,10.7756103687835),(106.682359764439,10.7756490693986),(106.682640114944,10.7758996628849),(106.682644070655,10.7759029839554),(106.682711710544,10.7759562859055),(106.682806505954,10.7760368956153),(106.68280745353,10.776037689352),(106.683169164535,10.7763361378178),(106.68363265876,10.7767252395911),(106.683677875719,10.7767650291442),(106.683797775698,10.77688614766),(106.684138558845,10.7772306328105),(106.68414063031,10.7772326552454),(106.684827531639,10.777880369263),(106.685228619785,10.7782605077038),(106.685228896163,10.7782607684525),(106.686025996525,10.7790093622583),(106.686026813787,10.7790101368229),(106.68658269265,10.7795369738106),(106.687194479537,10.7801158277128),(106.688401155505,10.7812670656457),(106.688401571342,10.7812674596561),(106.689622367701,10.7824162362891),(106.690002723257,10.7827815572149),(106.690002908997,10.7827817350625),(106.690359062158,10.7831217027417),(106.690359638585,10.7831222477508),(106.690747557266,10.7834855403784),(106.691628272565,10.7843952548301),(106.692179613338,10.7849709155958),(106.692179802225,10.7849711121697),(106.692743910048,10.7855562574979),(106.693288875836,10.7861225208133),(106.693601234729,10.7864484801726),(106.69220838651,10.7875617536129),(106.692196691453,10.787573150248),(106.692187444486,10.7875866094924),(106.692181000965,10.7876016141149),(106.692177608512,10.7876175874962),(106.692177397496,10.7876339157883),(106.692180376026,10.7876499715041),(106.692186429639,10.7876651376314),(106.692195325699,10.7876788313445),(106.692206722334,10.7876905264015),(106.692220181578,10.7876997733682),(106.692235186201,10.7877062168886),(106.692251159582,10.787709609342),(106.692267487874,10.7877098203582),(106.69228354359,10.7877068418281),(106.692298709717,10.7877007882148),(106.69231240343,10.7876918921553),(106.693776442708,10.7865217172423),(106.693788736175,10.7865096022178),(106.693798269005,10.7864952137411),(106.693804631934,10.7864791695437),(106.693807551784,10.7864621584413),(106.693806903199,10.7864449107613),(106.693802714026,10.7864281669878),(106.693795164114,10.786412645971),(106.693784577601,10.7863990140651),(106.69340910087,10.7860071886444),(106.69340897739,10.7860070600637),(106.692863924954,10.7854407067139),(106.69229983717,10.7848555821281),(106.691748435669,10.7842798579551),(106.691748124777,10.7842795350934),(106.690865834778,10.7833681940925),(106.690862927107,10.7833653342196),(106.690473809086,10.7830009183885),(106.690118035849,10.7826613133679),(106.689737465891,10.7822957865149),(106.689736848623,10.7822951996834),(106.688515950726,10.7811463275029),(106.687309357068,10.7799951680976),(106.687309106711,10.779994930232),(106.686697270266,10.7794160294802),(106.686141416688,10.7788892164565),(106.686140461741,10.7788883114),(106.686140185762,10.7788880510296),(106.6853430856,10.7781394574112),(106.684942058447,10.7777593767781),(106.684941904463,10.7777592312084),(106.684255979358,10.7771124377212),(106.683916204215,10.776768971525),(106.683794256559,10.7766457845149),(106.68379008676,10.7766418525893),(106.683741989497,10.7765995284558),(106.683740519326,10.7765982647987),(106.683276011394,10.7762083120217),(106.683275466929,10.7762078588774),(106.68291395946,10.77590957835),(106.682818451152,10.775828362424),(106.682816046951,10.7758263940715),(106.682749215964,10.7757737295564),(106.682469581984,10.775523776542),(106.682467121137,10.7755216616573),(106.682417839663,10.775480950083),(106.68241543796,10.7754790393628),(106.682411856108,10.7754762959601),(106.681948170223,10.775076801292),(106.681946953215,10.7750757728772),(106.681577943952,10.7747699480145),(106.681354856141,10.7745815499075),(106.681050071432,10.7743235726569),(106.680779998801,10.774093497693),(106.680779672798,10.7740932214111),(106.680427578845,10.7737963760106),(106.680284883706,10.7736759607876),(106.680120811518,10.7735325925854),(106.680120259999,10.7735321149047),(106.679882649978,10.7733281310479),(106.679742564868,10.7732015296478),(106.67973997054,10.7731992804165),(106.679159125009,10.772716304271),(106.679157929246,10.7727153285815),(106.679083371982,10.7726556350576),(106.679069423592,10.7726465921904),(106.679053957365,10.7726404990091),(106.679037589221,10.7726375981655),(106.679020970997,10.7726380051815),(106.679004764489,10.7726417038483),(106.678989615098,10.7726485468719),(106.678976126125,10.772658261739),(106.678449597495,10.7731239014943),(106.678407514754,10.773159565689),(106.678406188192,10.7731607141448),(106.678291034854,10.7732625482153),(106.678131577851,10.7733972356454),(106.678131249559,10.7733975143985),(106.677809116892,10.7736724741964),(106.677803734254,10.7736774962862),(106.67777351642,10.773708297704),(106.677376870851,10.7734422350384),(106.677376291861,10.7734418501559),(106.676943701895,10.7731568826838),(106.676941799819,10.7731556663352),(106.676705634648,10.7730091132449),(106.676468020922,10.7728596290723),(106.676467624617,10.7728593813034),(106.676202468827,10.7726946395397),(106.675976718772,10.7725542402878),(106.675713344944,10.7723904505946),(106.675438984881,10.7722195485022),(106.675160330528,10.7720443170291),(106.674980445983,10.7719313240966),(106.674980215342,10.7719311797465),(106.674747119479,10.7717858222138),(106.674497164595,10.7716283533947),(106.674495300219,10.7716272127471),(106.674339180867,10.7715344896819),(106.674338897981,10.771534322423),(106.674061493048,10.7713710419232),(106.674061328848,10.7713709455279),(106.673777295695,10.7712046366425),(106.673775349509,10.7712035319333),(106.673513740027,10.7710596467179),(106.673513190173,10.7710593469847),(106.673099330442,10.7708357600807),(106.673098966779,10.7708355647753),(106.672357083034,10.7704395002842),(106.672023628724,10.7702576558632),(106.671746880137,10.7701061587426),(106.671518215262,10.7699783515251),(106.671516207112,10.7699772649622),(106.671350083838,10.7698903014222),(106.671115399209,10.7697601522552),(106.671113600766,10.7697591835329),(106.670830326847,10.7696110514048),(106.66974820551,10.7689798847013),(106.66969475177,10.7688866833063),(106.669685913661,10.7688741199651),(106.669674918986,10.7688633930448),(106.669662141606,10.7688548673033),(106.668277363011,10.7681053993183),(106.668276514094,10.7681049461882),(106.668126503268,10.7680259842551),(106.668125839186,10.7680237950692),(106.66812072496,10.7680095017658),(106.668117596648,10.7680019493532),(106.66811110606,10.7679882261576),(106.668107252546,10.7679810167398),(106.668099448104,10.7679679958141),(106.668094906497,10.767961198818),(106.668085863361,10.7679490055608),(106.668080677403,10.7679426864524),(106.668070482664,10.7679314382913),(106.668064702296,10.7679256579236),(106.668053454135,10.7679154631847),(106.668047135024,10.7679102772246),(106.668034941766,10.7679012340887),(106.668028144776,10.7678966924853),(106.668015123851,10.7678888880428),(106.668007914429,10.7678850345264),(106.667994191233,10.7678785439383),(106.667986638821,10.7678754156266),(106.667972345518,10.7678703014008),(106.667964522841,10.7678679284177),(106.667949797082,10.7678642398071),(106.667941779481,10.7678626450072),(106.667926763083,10.767860417535),(106.667918627772,10.7678596162768),(106.667903465352,10.7678588713949),(106.667895290678,10.7678588713949),(106.667880128258,10.7678596162768),(106.667871992947,10.767860417535),(106.667856976549,10.7678626450072),(106.667848958948,10.7678642398071),(106.667848526162,10.7678643482145),(106.667629153721,10.7677506481269),(106.667628614008,10.7677503708842),(106.66744662399,10.7676577214203),(106.667216888626,10.7675408306262),(106.667161868227,10.7675128359024),(106.667012119458,10.7674366427911),(106.666659357657,10.7672571553777),(106.666673753979,10.7671954479766),(106.667048293768,10.7672739882109),(106.667012119458,10.7674366427911)] );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e28b65a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:16:06.414200 [ 24373 ] {} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (106.667, 10.7674); method: t; operations: x/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 4}/{0, -1, -1, 0}: In scope SELECT pointInPolygon((106.677085876465, 10.7744951248169), [(106.667161868227, 10.7675128359024), (106.667165727127, 10.7675059912261), (106.667170817563, 10.7674904752629), (106.667229225265, 10.7672278502066), (106.667231193621, 10.7672115129572), (106.667229912029, 10.7671951075415), (106.667225430503, 10.767179274157), (106.667217923927, 10.7671646306786), (106.667207685234, 10.7671517485471), (106.667195113975, 10.7671411304688), (106.667180700725, 10.7671331907989), (106.66716500794, 10.7671282393715), (106.666628232995, 10.7670156787539), (106.666612233649, 10.7670139127584), (106.666596193354, 10.7670152569112), (106.666580711053, 10.7670196610218), (106.666566364856, 10.7670269606408), (106.666553690448, 10.7670368832008), (106.666543161092, 10.767049058194), (106.666535169952, 10.7670630310067), (106.666530015418, 10.7670782798948), (106.666482284259, 10.7672828714379), (106.666480170141, 10.7672985245675), (106.666481048788, 10.7673142953614), (106.666484888609, 10.7673296167758), (106.666491551541, 10.7673439379244), (106.666500798017, 10.7673567438858), (106.666512295576, 10.7673675742178), (106.666525630821, 10.7673760395122), (106.667032331859, 10.7676338521733), (106.6671413386, 10.7676893154858), (106.667371048786, 10.7678061934666), (106.667552760053, 10.7678987010209), (106.667801848625, 10.7680278028917), (106.667817742281, 10.7680340673957), (106.667834579682, 10.7680369577679), (106.66785165264, 10.7680363524383), (106.667868243061, 10.7680322768672), (106.667878683314, 10.7680285412847), (106.667885469819, 10.7680268413536), (106.667892390269, 10.7680258148018), (106.667899378015, 10.7680254715159), (106.667906365761, 10.7680258148018), (106.667913286211, 10.7680268413536), (106.667920072716, 10.7680285412847), (106.667926659921, 10.7680308982244), (106.667932984386, 10.7680338894736), (106.667938985204, 10.7680374862253), (106.667944604583, 10.7680416538412), (106.667949788405, 10.7680463521828), (106.667954486747, 10.7680515360051), (106.667958654362, 10.7680571553826), (106.667962251113, 10.7680631561994), (106.667965242363, 10.7680694806664), (106.667967599303, 10.7680760678724), (106.667969299234, 10.7680828543774), (106.667970926246, 10.7680938227996), (106.667974657027, 10.7681089916695), (106.667981154238, 10.7681231972879), (106.667990189396, 10.7681359400994), (106.668001444773, 10.7681467719897), (106.668014524559, 10.7681553120441), (106.668198488147, 10.7682521458591), (106.669562015793, 10.7689901124345), (106.669614757162, 10.7690820717448), (106.669623023723, 10.7690939566151), (106.669633223154, 10.7691042307472), (106.669645047385, 10.7691125838155), (106.670748051536, 10.7697559307954), (106.670751419717, 10.7697577924329), (106.671035494073, 10.7699063431327), (106.671270162713, 10.7700364834325), (106.67127192876, 10.7700374352053), (106.671437929267, 10.7701243344783), (106.671665917937, 10.7702517637461), (106.67166656035, 10.7702521191025), (106.671943689514, 10.7704038245574), (106.671943806749, 10.7704038886117), (106.6722776446, 10.7705859421916), (106.672278295949, 10.7705862936499), (106.673020324076, 10.7709824352208), (106.673433726727, 10.7712057751884), (106.673694081332, 10.7713489702214), (106.673977066657, 10.7715146655761), (106.674254247937, 10.7716778144336), (106.67440928634, 10.7717698954974), (106.674658478275, 10.7719268836667), (106.674658802254, 10.7719270867325), (106.6748919449, 10.7720724734391), (106.675071660589, 10.7721853602936), (106.675350447469, 10.7723606751059), (106.675350748696, 10.7723608636368), (106.6756252856, 10.7725318758852), (106.675888735092, 10.7726957126602), (106.676114500069, 10.7728361211927), (106.676379504941, 10.7730007692002), (106.67661713771, 10.7731502653527), (106.676617572241, 10.773150536857), (106.676852995814, 10.7732966297465), (106.677284352687, 10.7735807849214), (106.677738143311, 10.7738851794554), (106.677752655777, 10.7738929549383), (106.677768414072, 10.773897724206), (106.677784802596, 10.7738993009456), (106.677801181124, 10.7738976235612), (106.677816909825, 10.7738927575805), (106.677831374252, 10.7738848930944), (106.677844009349, 10.7738743373313), (106.677920079221, 10.7737967983562), (106.678239245717, 10.7735243703649), (106.67839926068, 10.7733892116467), (106.678400691571, 10.7733879749217), (106.678515896101, 10.7732860955802), (106.678557979259, 10.7732504310319), (106.67855930664, 10.7732492818517), (106.679033975331, 10.7728295048433), (106.679053201911, 10.772844898411), (106.679632133733, 10.7733262832973), (106.679771732358, 10.7734524450384), (106.679773325229, 10.7734538481348), (106.680011463819, 10.7736582857586), (106.680175801881, 10.7738018862846), (106.680176891116, 10.7738028216402), (106.680320149367, 10.773923712053), (106.680672123374, 10.7742204563391), (106.68094213423, 10.7744504786771), (106.68094233625, 10.7744506502241), (106.68124725775, 10.7747087432576), (106.681247329066, 10.7747088035527), (106.681470746982, 10.7748974804345), (106.681471338135, 10.7748979749973), (106.681840030697, 10.7752035373868), (106.682304929691, 10.7756040772245), (106.682308650112, 10.7756071005185), (106.682312917236, 10.7756103687835), (106.682359764439, 10.7756490693986), (106.682640114944, 10.7758996628849), (106.682644070655, 10.7759029839554), (106.682711710544, 10.7759562859055), (106.682806505954, 10.7760368956153), (106.68280745353, 10.776037689352), (106.683169164535, 10.7763361378178), (106.68363265876, 10.7767252395911), (106.683677875719, 10.7767650291442), (106.683797775698, 10.77688614766), (106.684138558845, 10.7772306328105), (106.68414063031, 10.7772326552454), (106.684827531639, 10.777880369263), (106.685228619785, 10.7782605077038), (106.685228896163, 10.7782607684525), (106.686025996525, 10.7790093622583), (106.686026813787, 10.7790101368229), (106.68658269265, 10.7795369738106), (106.687194479537, 10.7801158277128), (106.688401155505, 10.7812670656457), (106.688401571342, 10.7812674596561), (106.689622367701, 10.7824162362891), (106.690002723257, 10.7827815572149), (106.690002908997, 10.7827817350625), (106.690359062158, 10.7831217027417), (106.690359638585, 10.7831222477508), (106.690747557266, 10.7834855403784), (106.691628272565, 10.7843952548301), (106.692179613338, 10.7849709155958), (106.692179802225, 10.7849711121697), (106.692743910048, 10.7855562574979), (106.693288875836, 10.7861225208133), (106.693601234729, 10.7864484801726), (106.69220838651, 10.7875617536129), (106.692196691453, 10.787573150248), (106.692187444486, 10.7875866094924), (106.692181000965, 10.7876016141149), (106.692177608512, 10.7876175874962), (106.692177397496, 10.7876339157883), (106.692180376026, 10.7876499715041), (106.692186429639, 10.7876651376314), (106.692195325699, 10.7876788313445), (106.692206722334, 10.7876905264015), (106.692220181578, 10.7876997733682), (106.692235186201, 10.7877062168886), (106.692251159582, 10.787709609342), (106.692267487874, 10.7877098203582), (106.69228354359, 10.7877068418281), (106.692298709717, 10.7877007882148), (106.69231240343, 10.7876918921553), (106.693776442708, 10.7865217172423), (106.693788736175, 10.7865096022178), (106.693798269005, 10.7864952137411), (106.693804631934, 10.7864791695437), (106.693807551784, 10.7864621584413), (106.693806903199, 10.7864449107613), (106.693802714026, 10.7864281669878), (106.693795164114, 10.786412645971), (106.693784577601, 10.7863990140651), (106.69340910087, 10.7860071886444), (106.69340897739, 10.7860070600637), (106.692863924954, 10.7854407067139), (106.69229983717, 10.7848555821281), (106.691748435669, 10.7842798579551), (106.691748124777, 10.7842795350934), (106.690865834778, 10.7833681940925), (106.690862927107, 10.7833653342196), (106.690473809086, 10.7830009183885), (106.690118035849, 10.7826613133679), (106.689737465891, 10.7822957865149), (106.689736848623, 10.7822951996834), (106.688515950726, 10.7811463275029), (106.687309357068, 10.7799951680976), (106.687309106711, 10.779994930232), (106.686697270266, 10.7794160294802), (106.686141416688, 10.7788892164565), (106.686140461741, 10.7788883114), (106.686140185762, 10.7788880510296), (106.6853430856, 10.7781394574112), (106.684942058447, 10.7777593767781), (106.684941904463, 10.7777592312084), (106.684255979358, 10.7771124377212), (106.683916204215, 10.776768971525), (106.683794256559, 10.7766457845149), (106.68379008676, 10.7766418525893), (106.683741989497, 10.7765995284558), (106.683740519326, 10.7765982647987), (106.683276011394, 10.7762083120217), (106.683275466929, 10.7762078588774), (106.68291395946, 10.77590957835), (106.682818451152, 10.775828362424), (106.682816046951, 10.7758263940715), (106.682749215964, 10.7757737295564), (106.682469581984, 10.775523776542), (106.682467121137, 10.7755216616573), (106.682417839663, 10.775480950083), (106.68241543796, 10.7754790393628), (106.682411856108, 10.7754762959601), (106.681948170223, 10.775076801292), (106.681946953215, 10.7750757728772), (106.681577943952, 10.7747699480145), (106.681354856141, 10.7745815499075), (106.681050071432, 10.7743235726569), (106.680779998801, 10.774093497693), (106.680779672798, 10.7740932214111), (106.680427578845, 10.7737963760106), (106.680284883706, 10.7736759607876), (106.680120811518, 10.7735325925854), (106.680120259999, 10.7735321149047), (106.679882649978, 10.7733281310479), (106.679742564868, 10.7732015296478), (106.67973997054, 10.7731992804165), (106.679159125009, 10.772716304271), (106.679157929246, 10.7727153285815), (106.679083371982, 10.7726556350576), (106.679069423592, 10.7726465921904), (106.679053957365, 10.7726404990091), (106.679037589221, 10.7726375981655), (106.679020970997, 10.7726380051815), (106.679004764489, 10.7726417038483), (106.678989615098, 10.7726485468719), (106.678976126125, 10.772658261739), (106.678449597495, 10.7731239014943), (106.678407514754, 10.773159565689), (106.678406188192, 10.7731607141448), (106.678291034854, 10.7732625482153), (106.678131577851, 10.7733972356454), (106.678131249559, 10.7733975143985), (106.677809116892, 10.7736724741964), (106.677803734254, 10.7736774962862), (106.67777351642, 10.773708297704), (106.677376870851, 10.7734422350384), (106.677376291861, 10.7734418501559), (106.676943701895, 10.7731568826838), (106.676941799819, 10.7731556663352), (106.676705634648, 10.7730091132449), (106.676468020922, 10.7728596290723), (106.676467624617, 10.7728593813034), (106.676202468827, 10.7726946395397), (106.675976718772, 10.7725542402878), (106.675713344944, 10.7723904505946), (106.675438984881, 10.7722195485022), (106.675160330528, 10.7720443170291), (106.674980445983, 10.7719313240966), (106.674980215342, 10.7719311797465), (106.674747119479, 10.7717858222138), (106.674497164595, 10.7716283533947), (106.674495300219, 10.7716272127471), (106.674339180867, 10.7715344896819), (106.674338897981, 10.771534322423), (106.674061493048, 10.7713710419232), (106.674061328848, 10.7713709455279), (106.673777295695, 10.7712046366425), (106.673775349509, 10.7712035319333), (106.673513740027, 10.7710596467179), (106.673513190173, 10.7710593469847), (106.673099330442, 10.7708357600807), (106.673098966779, 10.7708355647753), (106.672357083034, 10.7704395002842), (106.672023628724, 10.7702576558632), (106.671746880137, 10.7701061587426), (106.671518215262, 10.7699783515251), (106.671516207112, 10.7699772649622), (106.671350083838, 10.7698903014222), (106.671115399209, 10.7697601522552), (106.671113600766, 10.7697591835329), (106.670830326847, 10.7696110514048), (106.66974820551, 10.7689798847013), (106.66969475177, 10.7688866833063), (106.669685913661, 10.7688741199651), (106.669674918986, 10.7688633930448), (106.669662141606, 10.7688548673033), (106.668277363011, 10.7681053993183), (106.668276514094, 10.7681049461882), (106.668126503268, 10.7680259842551), (106.668125839186, 10.7680237950692), (106.66812072496, 10.7680095017658), (106.668117596648, 10.7680019493532), (106.66811110606, 10.7679882261576), (106.668107252546, 10.7679810167398), (106.668099448104, 10.7679679958141), (106.668094906497, 10.767961198818), (106.668085863361, 10.7679490055608), (106.668080677403, 10.7679426864524), (106.668070482664, 10.7679314382913), (106.668064702296, 10.7679256579236), (106.668053454135, 10.7679154631847), (106.668047135024, 10.7679102772246), (106.668034941766, 10.7679012340887), (106.668028144776, 10.7678966924853), (106.668015123851, 10.7678888880428), (106.668007914429, 10.7678850345264), (106.667994191233, 10.7678785439383), (106.667986638821, 10.7678754156266), (106.667972345518, 10.7678703014008), (106.667964522841, 10.7678679284177), (106.667949797082, 10.7678642398071), (106.667941779481, 10.7678626450072), (106.667926763083, 10.767860417535), (106.667918627772, 10.7678596162768), (106.667903465352, 10.7678588713949), (106.667895290678, 10.7678588713949), (106.667880128258, 10.7678596162768), (106.667871992947, 10.767860417535), (106.667856976549, 10.7678626450072), (106.667848958948, 10.7678642398071), (106.667848526162, 10.7678643482145), (106.667629153721, 10.7677506481269), (106.667628614008, 10.7677503708842), (106.66744662399, 10.7676577214203), (106.667216888626, 10.7675408306262), (106.667161868227, 10.7675128359024), (106.667012119458, 10.7674366427911), (106.666659357657, 10.7672571553777), (106.666673753979, 10.7671954479766), (106.667048293768, 10.7672739882109), (106.667012119458, 10.7674366427911)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e28b65a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:16:07.065880 [ 2054 ] {5a79ef2f-b169-4616-ba26-f10ed708c590} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: JSONLength('^?V{LSwp'): In scope SELECT JSONExtractKeysAndValues([], JSONLength('^?V{LSwp')). (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43066) (comment: 00918_json_functions.sql) (query 280, line 321) (in query: SELECT JSONExtractKeysAndValues([], JSONLength('^?V{LSwp'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. DB::JSONExtractKeysAndValuesImpl::getReturnType(char const*, std::vector> const&) @ 0x000000000907f061 5. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x000000000907e1aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:16:07.067026 [ 2054 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: JSONLength('^?V{LSwp'): In scope SELECT JSONExtractKeysAndValues([], JSONLength('^?V{LSwp')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. DB::JSONExtractKeysAndValuesImpl::getReturnType(char const*, std::vector> const&) @ 0x000000000907f061 5. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x000000000907e1aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:16:07.077629 [ 2054 ] {8b40a1fb-4ded-4ba3-a08e-015d6e19dfbd} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: JSONType(json, 'i'): In scope WITH '{"i": 1, "f": 1.2}' AS json SELECT JSONExtract(json, 'i', JSONType(json, 'i')). (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43066) (comment: 00918_json_functions.sql) (query 281, line 322) (in query: WITH '{"i": 1, "f": 1.2}' AS json SELECT JSONExtract(json, 'i', JSONType(json, 'i'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. DB::JSONExtractImpl::getReturnType(char const*, std::vector> const&) @ 0x000000000907a243 5. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x00000000090798aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:16:07.078986 [ 2054 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: JSONType(json, 'i'): In scope WITH '{"i": 1, "f": 1.2}' AS json SELECT JSONExtract(json, 'i', JSONType(json, 'i')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. DB::JSONExtractImpl::getReturnType(char const*, std::vector> const&) @ 0x000000000907a243 5. DB::JSONOverloadResolver::build(std::vector> const&) const @ 0x00000000090798aa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:16:07.290667 [ 2054 ] {07f8c27e-10d7-4b78-9b1b-4c6b58f8f5e1} executeQuery: Code: 43. DB::Exception: The argument 2 of function JSONExtract should be a string specifying key or an integer specifying index, illegal type: UInt256: In scope SELECT JSONExtract('[]', JSONExtract('0', 'UInt256'), 'UInt256'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43066) (comment: 00918_json_functions.sql) (query 283, line 325) (in query: SELECT JSONExtract('[]', JSONExtract('0', 'UInt256'), 'UInt256');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionJSONHelpers::prepareMoves(char const*, std::vector> const&, unsigned long, unsigned long) @ 0x000000000904f4d7 5. DB::FunctionJSONHelpers::Executor::run(std::vector> const&, std::shared_ptr const&, unsigned long, DB::FormatSettings const&) @ 0x000000000907cb6e 6. DB::ExecutableFunctionJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000907b8ad 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:16:07.292602 [ 2054 ] {} TCPHandler: Code: 43. DB::Exception: The argument 2 of function JSONExtract should be a string specifying key or an integer specifying index, illegal type: UInt256: In scope SELECT JSONExtract('[]', JSONExtract('0', 'UInt256'), 'UInt256'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionJSONHelpers::prepareMoves(char const*, std::vector> const&, unsigned long, unsigned long) @ 0x000000000904f4d7 5. DB::FunctionJSONHelpers::Executor::run(std::vector> const&, std::shared_ptr const&, unsigned long, DB::FormatSettings const&) @ 0x000000000907cb6e 6. DB::ExecutableFunctionJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000907b8ad 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:16:07.447836 [ 2054 ] {5eff90d4-553c-4510-9cb7-186b540e92c8} executeQuery: Code: 43. DB::Exception: JSONExtract doesn't support the return type schema: Map(Int64, Array(Float64)) with key type not String: In scope SELECT JSONExtract('{"a": [100.0, 200], "b": [-100, 200.0, 300]}', 'Map(Int64, Array(Float64))'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43066) (comment: 00918_json_functions.sql) (query 285, line 328) (in query: SELECT JSONExtract('{"a": [100.0, 200], "b": [-100, 200.0, 300]}', 'Map(Int64, Array(Float64))');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&, String&&) @ 0x000000001415f826 4. ./build_docker/./src/Formats/JSONExtractTree.cpp:1946: std::unique_ptr, std::default_delete>> DB::buildJSONExtractTree(std::shared_ptr const&, char const*) @ 0x000000001bc87a4e 5. DB::FunctionJSONHelpers::Executor::run(std::vector> const&, std::shared_ptr const&, unsigned long, DB::FormatSettings const&) @ 0x000000000907cc29 6. DB::ExecutableFunctionJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000907b8ad 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:16:07.449179 [ 2054 ] {} TCPHandler: Code: 43. DB::Exception: JSONExtract doesn't support the return type schema: Map(Int64, Array(Float64)) with key type not String: In scope SELECT JSONExtract('{"a": [100.0, 200], "b": [-100, 200.0, 300]}', 'Map(Int64, Array(Float64))'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&, String&&) @ 0x000000001415f826 4. ./build_docker/./src/Formats/JSONExtractTree.cpp:1946: std::unique_ptr, std::default_delete>> DB::buildJSONExtractTree(std::shared_ptr const&, char const*) @ 0x000000001bc87a4e 5. DB::FunctionJSONHelpers::Executor::run(std::vector> const&, std::shared_ptr const&, unsigned long, DB::FormatSettings const&) @ 0x000000000907cc29 6. DB::ExecutableFunctionJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000907b8ad 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:16:08.630844 [ 1855 ] {test_ucftx9pv_1753694168_02883_q1} executeQuery: Code: 47. DB::Exception: Unknown expression or table expression identifier `sub` in scope SELECT * FROM system.numbers WHERE number IN (sub). Maybe you meant: ['sub']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54442) (comment: 02483_elapsed_time.sh) (query 1, line 1) (in query: WITH ( SELECT sleepEachRow(1) ) AS sub SELECT * FROM ( SELECT * FROM system.numbers WHERE number IN (sub) ) SETTINGS enable_global_with_statement = 0, enable_analyzer = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5630: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7f0b0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a86fde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc6d9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:16:08.632579 [ 1855 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or table expression identifier `sub` in scope SELECT * FROM system.numbers WHERE number IN (sub). Maybe you meant: ['sub']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5630: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7f0b0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a86fde 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc6d9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:16:10.466058 [ 17255 ] {9fa7a89d-2fa0-42f9-8b0f-b81c85fc4448} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 27. DB::Exception: Cannot parse input: expected 'true' before: '}': (while reading the value of key x): (at row 1) . (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000010c325ec 5. ./build_docker/./src/IO/ReadHelpers.cpp:131: DB::assertString(char const*, DB::ReadBuffer&) @ 0x0000000010c32a88 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:380: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000176021c3 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000017594358 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000001bca198c 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becafe4 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becb324 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001becbe75 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001bf46e17 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001bf4509e 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bf484f8 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000001bf4669d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000001bf4459d 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000001bf49950 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bf49802 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000001bf47c02 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000001bf46477 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001bd27481 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013d056ab 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 16. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 32. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 33. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 34. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 35. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 36. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 37. __tsan_thread_start_func @ 0x0000000008756428 38. ? @ 0x00007fecd6763ac3 39. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:10.469371 [ 1859 ] {9fa7a89d-2fa0-42f9-8b0f-b81c85fc4448} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected 'true' before: '}': (while reading the value of key x): (at row 1) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54514) (comment: 02961_read_bool_as_string_json.sql) (query 4, line 4) (in query: select * from format(JSONEachRow, 'x String', '{"x" : tru}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000010c325ec 5. ./build_docker/./src/IO/ReadHelpers.cpp:131: DB::assertString(char const*, DB::ReadBuffer&) @ 0x0000000010c32a88 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:380: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000176021c3 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000017594358 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000001bca198c 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becafe4 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becb324 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001becbe75 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001bf46e17 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001bf4509e 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bf484f8 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:16:10.471610 [ 1859 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected 'true' before: '}': (while reading the value of key x): (at row 1) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000010c325ec 5. ./build_docker/./src/IO/ReadHelpers.cpp:131: DB::assertString(char const*, DB::ReadBuffer&) @ 0x0000000010c32a88 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:380: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000176021c3 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000017594358 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000001bca198c 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becafe4 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becb324 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001becbe75 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001bf46e17 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001bf4509e 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bf484f8 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000001bf4669d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000001bf4459d 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000001bf49950 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bf49802 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000001bf47c02 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000001bf46477 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001bd27481 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013d056ab 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 16. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 32. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 33. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 34. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 35. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 36. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 37. __tsan_thread_start_func @ 0x0000000008756428 38. ? @ 0x00007fecd6763ac3 39. ? @ 0x00007fecd67f5850 2025.07.28 06:16:10.606710 [ 17257 ] {2a5106a7-c413-480c-9a62-5e8568e10a92} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 27. DB::Exception: Cannot parse input: expected 'false' before: '}': (while reading the value of key x): (at row 1) . (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000010c325ec 5. ./build_docker/./src/IO/ReadHelpers.cpp:131: DB::assertString(char const*, DB::ReadBuffer&) @ 0x0000000010c32a88 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:385: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000017602574 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000017594358 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000001bca198c 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becafe4 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becb324 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001becbe75 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001bf46e17 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001bf4509e 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bf484f8 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000001bf4669d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000001bf4459d 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000001bf49950 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bf49802 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000001bf47c02 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000001bf46477 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001bd27481 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013d056ab 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 16. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 32. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 33. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 34. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 35. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 36. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 37. __tsan_thread_start_func @ 0x0000000008756428 38. ? @ 0x00007fecd6763ac3 39. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:10.609455 [ 1859 ] {2a5106a7-c413-480c-9a62-5e8568e10a92} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected 'false' before: '}': (while reading the value of key x): (at row 1) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54514) (comment: 02961_read_bool_as_string_json.sql) (query 5, line 5) (in query: select * from format(JSONEachRow, 'x String', '{"x" : fals}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000010c325ec 5. ./build_docker/./src/IO/ReadHelpers.cpp:131: DB::assertString(char const*, DB::ReadBuffer&) @ 0x0000000010c32a88 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:385: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000017602574 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000017594358 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000001bca198c 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becafe4 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becb324 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001becbe75 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001bf46e17 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001bf4509e 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bf484f8 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:16:10.611404 [ 1859 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected 'false' before: '}': (while reading the value of key x): (at row 1) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000010c325ec 5. ./build_docker/./src/IO/ReadHelpers.cpp:131: DB::assertString(char const*, DB::ReadBuffer&) @ 0x0000000010c32a88 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:385: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000017602574 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000017594358 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000001bca198c 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becafe4 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becb324 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001becbe75 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001bf46e17 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001bf4509e 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bf484f8 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000001bf4669d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000001bf4459d 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000001bf49950 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bf49802 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000001bf47c02 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000001bf46477 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001bd27481 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013d056ab 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 16. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 32. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 33. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 34. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 35. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 36. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 37. __tsan_thread_start_func @ 0x0000000008756428 38. ? @ 0x00007fecd6763ac3 39. ? @ 0x00007fecd67f5850 2025.07.28 06:16:10.736618 [ 1394 ] {becbf3de-6bab-4291-97e7-629ca5f4a821} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 117. DB::Exception: Cannot read JSON field here: 'atru}'. Unexpected symbol 'a': (while reading the value of key x): (at row 1) . (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/IO/ReadHelpers.cpp:1774: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000010c52199 5. ./build_docker/./src/IO/ReadHelpers.cpp:1789: DB::readJSONField(String&, DB::ReadBuffer&, DB::FormatSettings::JSON const&) @ 0x0000000010c380c1 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:394: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000017602268 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000017594358 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000001bca198c 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becafe4 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becb324 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001becbe75 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001bf46e17 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001bf4509e 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bf484f8 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000001bf4669d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000001bf4459d 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000001bf49950 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bf49802 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000001bf47c02 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000001bf46477 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001bd27481 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013d056ab 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 16. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 32. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 33. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 34. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 35. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 36. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 37. __tsan_thread_start_func @ 0x0000000008756428 38. ? @ 0x00007fecd6763ac3 39. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:10.739066 [ 1859 ] {becbf3de-6bab-4291-97e7-629ca5f4a821} executeQuery: Code: 117. DB::Exception: Cannot read JSON field here: 'atru}'. Unexpected symbol 'a': (while reading the value of key x): (at row 1) : While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54514) (comment: 02961_read_bool_as_string_json.sql) (query 6, line 6) (in query: select * from format(JSONEachRow, 'x String', '{"x" : atru}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/IO/ReadHelpers.cpp:1774: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000010c52199 5. ./build_docker/./src/IO/ReadHelpers.cpp:1789: DB::readJSONField(String&, DB::ReadBuffer&, DB::FormatSettings::JSON const&) @ 0x0000000010c380c1 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:394: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000017602268 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000017594358 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000001bca198c 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becafe4 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becb324 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001becbe75 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001bf46e17 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001bf4509e 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bf484f8 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:16:10.740807 [ 1859 ] {} TCPHandler: Code: 117. DB::Exception: Cannot read JSON field here: 'atru}'. Unexpected symbol 'a': (while reading the value of key x): (at row 1) : While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. ./build_docker/./src/IO/ReadHelpers.cpp:1774: void DB::skipJSONFieldImpl(DB::ReadBuffer&, std::basic_string_view>, DB::FormatSettings::JSON const&, unsigned long) @ 0x0000000010c52199 5. ./build_docker/./src/IO/ReadHelpers.cpp:1789: DB::readJSONField(String&, DB::ReadBuffer&, DB::FormatSettings::JSON const&) @ 0x0000000010c380c1 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:394: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000017602268 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000017594358 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000001bca198c 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becafe4 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000001becb324 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001becbe75 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001bf46e17 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001bf4509e 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bf484f8 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000001bf4669d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000001bf4459d 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000001bf49950 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bf49802 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000001bf47c02 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000001bf46477 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001bd27481 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013d056ab 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 16. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 32. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 33. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 34. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 35. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 36. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 37. __tsan_thread_start_func @ 0x0000000008756428 38. ? @ 0x00007fecd6763ac3 39. ? @ 0x00007fecd67f5850 2025.07.28 06:16:14.693280 [ 24367 ] {f6a224e6-916d-4969-8bae-d2b1856dc340} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59044) (comment: 00336_shard_stack_trace.sh) (in query: SELECT a), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:14.700910 [ 24367 ] {f6a224e6-916d-4969-8bae-d2b1856dc340} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:14.723341 [ 1860 ] {3e69f19f-8c90-45f6-ab41-6f74263d35ef} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59052) (comment: 00336_shard_stack_trace.sh) (in query: SELECT a), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:14.724878 [ 1860 ] {3e69f19f-8c90-45f6-ab41-6f74263d35ef} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:14.743279 [ 1860 ] {1a457d7e-5633-4f8d-94b5-15deeec2e7be} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59058) (comment: 00336_shard_stack_trace.sh) (in query: SELECT a), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:14.745288 [ 1860 ] {1a457d7e-5633-4f8d-94b5-15deeec2e7be} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 18. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 19. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:14.951880 [ 1860 ] {795d2eb7-3cb8-42ad-baa0-e8c06d303fe3} executeQuery: Code: 153. DB::Exception: Division by zero. (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59070) (comment: 00336_shard_stack_trace.sh) (in query: SELECT intDiv(number, 0) FROM remote('127.0.0.{2,3}', system.numbers)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::(anonymous namespace)::DivideIntegralByConstantImpl::vectorConstant(unsigned long const*, char8_t, unsigned long*, unsigned long) @ 0x000000000b9d1e28 5. void DB::(anonymous namespace)::DivideIntegralByConstantImpl::process<(DB::impl_::OpCase)2>(unsigned long const*, char8_t const*, unsigned long*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000b9d1d58 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc9846c 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc965ba 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc6bb61 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc66e33 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc65846 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc6447e 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 20. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 22. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 23. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 24. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 25. ./build_docker/./src/Planner/Planner.cpp:243: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000001897db88 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018979015 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 2025.07.28 06:16:14.956501 [ 1860 ] {795d2eb7-3cb8-42ad-baa0-e8c06d303fe3} DynamicQueryHandler: Code: 153. DB::Exception: Division by zero. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::(anonymous namespace)::DivideIntegralByConstantImpl::vectorConstant(unsigned long const*, char8_t, unsigned long*, unsigned long) @ 0x000000000b9d1e28 5. void DB::(anonymous namespace)::DivideIntegralByConstantImpl::process<(DB::impl_::OpCase)2>(unsigned long const*, char8_t const*, unsigned long*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000b9d1d58 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc9846c 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc965ba 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc6bb61 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc66e33 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc65846 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc6447e 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 20. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 22. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 23. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 24. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 25. ./build_docker/./src/Planner/Planner.cpp:243: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000001897db88 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018979015 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:15.390938 [ 2054 ] {a4a6ccf9-91a1-40c5-b918-2c6872b6c83f} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54752) (comment: 00336_shard_stack_trace.sh) (query 1, line 1) (in query: SELECT a), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:16:15.394045 [ 2054 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:16:15.959613 [ 24374 ] {e5fd3310-238d-4433-bb40-4381b3921406} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54798) (comment: 00336_shard_stack_trace.sh) (query 1, line 1) (in query: SELECT a), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:16:15.961460 [ 24374 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT a. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:16:16.484453 [ 1860 ] {45273916-69ed-4838-a5ba-9d276a2452dc} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'memory' in scope SELECT count() FROM memory WHERE NOT ignore(sleep(0.0001)). (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54834) (comment: 00704_drop_truncate_memory_table.sh) (query 2, line 3) (in query: SELECT count() FROM memory WHERE NOT ignore(sleep(0.0001));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:16:16.486109 [ 1860 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'memory' in scope SELECT count() FROM memory WHERE NOT ignore(sleep(0.0001)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:16:16.633102 [ 2054 ] {f6d1ac0e-ee20-4701-ba12-1e6651cb6795} executeQuery: Code: 153. DB::Exception: Division by zero. (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54852) (comment: 00336_shard_stack_trace.sh) (query 1, line 1) (in query: SELECT intDiv(number, 0) FROM remote('127.0.0.{2,3}', system.numbers)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::(anonymous namespace)::DivideIntegralByConstantImpl::vectorConstant(unsigned long const*, char8_t, unsigned long*, unsigned long) @ 0x000000000b9d1e28 5. void DB::(anonymous namespace)::DivideIntegralByConstantImpl::process<(DB::impl_::OpCase)2>(unsigned long const*, char8_t const*, unsigned long*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000b9d1d58 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc9846c 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc965ba 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc6bb61 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc66e33 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc65846 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc6447e 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 20. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 22. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 23. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 24. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 25. ./build_docker/./src/Planner/Planner.cpp:243: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000001897db88 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018979015 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:16:16.638425 [ 2054 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::(anonymous namespace)::DivideIntegralByConstantImpl::vectorConstant(unsigned long const*, char8_t, unsigned long*, unsigned long) @ 0x000000000b9d1e28 5. void DB::(anonymous namespace)::DivideIntegralByConstantImpl::process<(DB::impl_::OpCase)2>(unsigned long const*, char8_t const*, unsigned long*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000b9d1d58 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc9846c 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc965ba 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000bc6bb61 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000bc66e33 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc65846 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000bc6447e 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 20. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 22. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 23. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 24. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 25. ./build_docker/./src/Planner/Planner.cpp:243: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000001897db88 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018979015 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:16:17.922563 [ 24374 ] {0704920f-fbd7-42b7-9c29-c790f2b05200} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47502) (comment: 02006_test_positional_arguments.sql) (query 38, line 49) (in query: select max(x1), x2 from test group by 1, 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af22b9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:17.924076 [ 24374 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af22b9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:18.035263 [ 24374 ] {f0ac9a36-9894-4cbc-befd-fa1fc430335c} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47502) (comment: 02006_test_positional_arguments.sql) (query 39, line 50) (in query: select 1 + max(x1), x2 from test group by 1, 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 8. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af22b9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:16:18.036685 [ 24374 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 8. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af22b9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:16:18.047148 [ 24374 ] {4fc0ec32-5c40-4c5b-b7ba-94e32d8dc63b} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47502) (comment: 02006_test_positional_arguments.sql) (query 40, line 51) (in query: select max(x1), x2 from test group by -2, -1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af22b9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:18.048114 [ 24374 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af22b9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:18.056736 [ 24374 ] {70fec172-d753-43ea-b074-3f5bc8de2aff} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47502) (comment: 02006_test_positional_arguments.sql) (query 41, line 52) (in query: select 1 + max(x1), x2 from test group by -2, -1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 8. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af22b9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:16:18.057877 [ 24374 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 8. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af22b9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:16:23.073776 [ 2095 ] {d2cdc298-89e9-4f7b-a7c5-209578ec733c} executeQuery: Code: 42. DB::Exception: Function arraySymmetricDifference requires at least one argument.: In scope SELECT arraySymmetricDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47782) (comment: 03357_arraySymmetricDifference.sql) (query 2, line 2) (in query: SELECT arraySymmetricDifference();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000010264c49 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:16:23.075121 [ 2095 ] {} TCPHandler: Code: 42. DB::Exception: Function arraySymmetricDifference requires at least one argument.: In scope SELECT arraySymmetricDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000010264c49 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:16:23.212815 [ 2095 ] {846e63f8-c44a-45c0-8dcb-761497c3c4e5} executeQuery: Code: 43. DB::Exception: Argument 0 for function arraySymmetricDifference must be an array but it has type UInt8.: In scope SELECT arraySymmetricDifference(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47782) (comment: 03357_arraySymmetricDifference.sql) (query 3, line 3) (in query: SELECT arraySymmetricDifference(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000ec6672c 4. DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000010264b9f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:16:23.213958 [ 2095 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function arraySymmetricDifference must be an array but it has type UInt8.: In scope SELECT arraySymmetricDifference(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000ec6672c 4. DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000010264b9f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:16:23.221106 [ 2095 ] {a270b870-0284-466a-8f3b-8d66bead2701} executeQuery: Code: 43. DB::Exception: Argument 0 for function arraySymmetricDifference must be an array but it has type UInt8.: In scope SELECT arraySymmetricDifference(1, 2). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47782) (comment: 03357_arraySymmetricDifference.sql) (query 4, line 4) (in query: SELECT arraySymmetricDifference(1, 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000ec6672c 4. DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000010264b9f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:16:23.222027 [ 2095 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function arraySymmetricDifference must be an array but it has type UInt8.: In scope SELECT arraySymmetricDifference(1, 2). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000ec6672c 4. DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000010264b9f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:16:23.228478 [ 2095 ] {9bd522e3-8c26-4824-b870-a2f55b0d3b37} executeQuery: Code: 43. DB::Exception: Argument 0 for function arraySymmetricDifference must be an array but it has type UInt8.: In scope SELECT arraySymmetricDifference(1, [1, 2]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47782) (comment: 03357_arraySymmetricDifference.sql) (query 5, line 5) (in query: SELECT arraySymmetricDifference(1, [1, 2]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000ec6672c 4. DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000010264b9f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:16:23.229352 [ 2095 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function arraySymmetricDifference must be an array but it has type UInt8.: In scope SELECT arraySymmetricDifference(1, [1, 2]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000ec6672c 4. DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000010264b9f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:16:23.235458 [ 2095 ] {3e98d7bc-a55d-4b44-9888-c11c634d8312} executeQuery: Code: 43. DB::Exception: Argument 1 for function arraySymmetricDifference must be an array but it has type UInt8.: In scope SELECT arraySymmetricDifference([1, 2], 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47782) (comment: 03357_arraySymmetricDifference.sql) (query 6, line 6) (in query: SELECT arraySymmetricDifference([1, 2], 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000ec6672c 4. DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000010264b9f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:16:23.236348 [ 2095 ] {} TCPHandler: Code: 43. DB::Exception: Argument 1 for function arraySymmetricDifference must be an array but it has type UInt8.: In scope SELECT arraySymmetricDifference([1, 2], 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000ec6672c 4. DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000010264b9f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:16:31.229919 [ 2114 ] {e47b49b0-b120-4e61-bcb5-eeea9f6f480c} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPaths. Expected single argument with type JSON, got 0 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54720) (comment: 03227_distinct_dynamic_types_json_paths.sql) (query 42, line 53) (in query: select distinctJSONPaths() from test_json_dynamic_aggregate_functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000950c126 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctJSONPaths.cpp:337: std::shared_ptr DB::createAggregateFunctionDistinctJSONPathsAndTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b500b3 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:31.236162 [ 2114 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPaths. Expected single argument with type JSON, got 0 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000950c126 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctJSONPaths.cpp:337: std::shared_ptr DB::createAggregateFunctionDistinctJSONPathsAndTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b500b3 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:31.255346 [ 2114 ] {86b039de-b348-4485-b20e-253327e85302} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPaths. Expected single argument with type JSON, got 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54720) (comment: 03227_distinct_dynamic_types_json_paths.sql) (query 43, line 54) (in query: select distinctJSONPaths(json, 42) from test_json_dynamic_aggregate_functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000950c126 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctJSONPaths.cpp:337: std::shared_ptr DB::createAggregateFunctionDistinctJSONPathsAndTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b500b3 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:31.257807 [ 2114 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPaths. Expected single argument with type JSON, got 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000950c126 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctJSONPaths.cpp:337: std::shared_ptr DB::createAggregateFunctionDistinctJSONPathsAndTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b500b3 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:31.582489 [ 2114 ] {2da68061-a54a-4c2d-a24f-7364e0299a7b} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument for aggregate function distinctJSONPaths. Expected type JSON. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54720) (comment: 03227_distinct_dynamic_types_json_paths.sql) (query 44, line 55) (in query: select distinctJSONPaths(42) from test_json_dynamic_aggregate_functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctJSONPaths.cpp:341: std::shared_ptr DB::createAggregateFunctionDistinctJSONPathsAndTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b50149 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:31.584030 [ 2114 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument for aggregate function distinctJSONPaths. Expected type JSON. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctJSONPaths.cpp:341: std::shared_ptr DB::createAggregateFunctionDistinctJSONPathsAndTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b50149 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:31.744799 [ 2114 ] {8237bdab-b440-437b-9959-c22ce54f48d4} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPathsAndTypes. Expected single argument with type JSON, got 0 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54720) (comment: 03227_distinct_dynamic_types_json_paths.sql) (query 45, line 56) (in query: select distinctJSONPathsAndTypes() from test_json_dynamic_aggregate_functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000950c126 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctJSONPaths.cpp:337: std::shared_ptr DB::createAggregateFunctionDistinctJSONPathsAndTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b50393 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:31.746010 [ 2114 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPathsAndTypes. Expected single argument with type JSON, got 0 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000950c126 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctJSONPaths.cpp:337: std::shared_ptr DB::createAggregateFunctionDistinctJSONPathsAndTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b50393 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:31.754340 [ 2114 ] {53cc8f75-f43f-4d87-a447-0ecc35a34b45} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPathsAndTypes. Expected single argument with type JSON, got 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54720) (comment: 03227_distinct_dynamic_types_json_paths.sql) (query 46, line 57) (in query: select distinctJSONPathsAndTypes(json, 42) from test_json_dynamic_aggregate_functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000950c126 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctJSONPaths.cpp:337: std::shared_ptr DB::createAggregateFunctionDistinctJSONPathsAndTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b50393 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:31.755363 [ 2114 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPathsAndTypes. Expected single argument with type JSON, got 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000950c126 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctJSONPaths.cpp:337: std::shared_ptr DB::createAggregateFunctionDistinctJSONPathsAndTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b50393 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:31.879326 [ 2114 ] {bb62287f-14cc-4fa7-ba6e-0edf0007e1cc} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument for aggregate function distinctJSONPathsAndTypes. Expected type JSON. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54720) (comment: 03227_distinct_dynamic_types_json_paths.sql) (query 47, line 58) (in query: select distinctJSONPathsAndTypes(42) from test_json_dynamic_aggregate_functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctJSONPaths.cpp:341: std::shared_ptr DB::createAggregateFunctionDistinctJSONPathsAndTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b50429 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:31.880366 [ 2114 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument for aggregate function distinctJSONPathsAndTypes. Expected type JSON. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctJSONPaths.cpp:341: std::shared_ptr DB::createAggregateFunctionDistinctJSONPathsAndTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b50429 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:32.007591 [ 2114 ] {8eb75cfb-42f6-41d0-9873-5af89061ae67} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctDynamicTypes. Expected single argument with type Dynamic, got 0 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54720) (comment: 03227_distinct_dynamic_types_json_paths.sql) (query 48, line 59) (in query: select distinctDynamicTypes() from test_json_dynamic_aggregate_functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000950c126 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctDynamicTypes.cpp:147: DB::createAggregateFunctionDistinctDynamicTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b4b4d3 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:32.009118 [ 2114 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctDynamicTypes. Expected single argument with type Dynamic, got 0 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000950c126 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctDynamicTypes.cpp:147: DB::createAggregateFunctionDistinctDynamicTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b4b4d3 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:32.020343 [ 2114 ] {6add719a-0815-4501-a8bf-b2b3b4e4c230} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctDynamicTypes. Expected single argument with type Dynamic, got 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54720) (comment: 03227_distinct_dynamic_types_json_paths.sql) (query 49, line 60) (in query: select distinctDynamicTypes(json.a2, 42) from test_json_dynamic_aggregate_functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000950c126 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctDynamicTypes.cpp:147: DB::createAggregateFunctionDistinctDynamicTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b4b4d3 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:32.021469 [ 2114 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctDynamicTypes. Expected single argument with type Dynamic, got 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000950c126 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctDynamicTypes.cpp:147: DB::createAggregateFunctionDistinctDynamicTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b4b4d3 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:32.147312 [ 2114 ] {69ebb65f-a243-4447-80e7-a402ee97f9ff} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument for aggregate function distinctDynamicTypes. Expected type Dynamic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54720) (comment: 03227_distinct_dynamic_types_json_paths.sql) (query 50, line 61) (in query: select distinctDynamicTypes(42) from test_json_dynamic_aggregate_functions;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctDynamicTypes.cpp:151: DB::createAggregateFunctionDistinctDynamicTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b4b569 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:32.149018 [ 2114 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument for aggregate function distinctDynamicTypes. Expected type Dynamic. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDistinctDynamicTypes.cpp:151: DB::createAggregateFunctionDistinctDynamicTypes(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000013b4b569 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:37.703968 [ 1860 ] {2fcc90ab-410e-454f-8f95-0faddfc298af} executeQuery: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([toUInt64(1)], [1], 18446744073709551615). (TOO_LARGE_ARRAY_SIZE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53048) (comment: 01698_map_populate_overflow.sql) (query 2, line 2) (in query: SELECT mapPopulateSeries([toUInt64(1)], [1], 0xFFFFFFFFFFFFFFFF);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x000000001089b59d 5. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x000000001089a9d1 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000107ff566 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:16:37.705471 [ 1860 ] {} TCPHandler: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([toUInt64(1)], [1], 18446744073709551615). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x000000001089b59d 5. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x000000001089a9d1 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000107ff566 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:16:38.341610 [ 2095 ] {dd963ff1-707b-4e02-a470-7627d08bbaa9} executeQuery: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53132) (comment: 01762_deltasumtimestamp_datetime64.sh) (query 1, line 1) (in query: SELECT deltaSumTimestamp(1, now64());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:237: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000113fc013 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:38.344083 [ 2095 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:237: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000113fc013 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000110ddb9e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471413 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001646f607 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa73e2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:16:39.380059 [ 1056 ] {} test_zyqh1o5u.alter_table1 (a7ac0d4f-7975-4b5b-bbeb-33d4d4486d55): Part /var/lib/clickhouse/store/a7a/a7ac0d4f-7975-4b5b-bbeb-33d4d4486d55/detached/all_7_7_0/ is broken and needs manual correction. Reason: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/store/a7a/a7ac0d4f-7975-4b5b-bbeb-33d4d4486d55/detached/all_7_7_0/checksums.txt: , errno: 2, strerror: No such file or directory. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000010c0e8e5 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000010c0e5bd 5. ./build_docker/./src/IO/OpenedFile.cpp:33: DB::OpenedFile::getFD() const @ 0x0000000016497d23 6. ./src/IO/ReadBufferFromFile.h:101: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000001648fe7b 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x000000001648f78b 8. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000001648f618 9. ./build_docker/./src/Disks/DiskLocal.cpp:343: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x0000000017862f93 10. ./build_docker/./src/Disks/IDisk.cpp:82: DB::IDisk::readFileIfExists(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x0000000017877c2a 11. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:140: DB::DataPartStorageOnDiskFull::readFileIfExists(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000001b1a97c0 12. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2611: DB::IMergeTreeDataPart::readFileIfExists(String const&) const @ 0x000000001b1f061f 13. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:1322: DB::IMergeTreeDataPart::loadChecksums(bool) @ 0x000000001b1f3497 14. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:840: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000001b1f0938 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x000000001ac7b2dd 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001ac7c441 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000001ada4421 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b725a6a 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000001acd1c9b 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001ada5429 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b1e046e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d5cdf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2d6a10 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc4c2 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:39.412821 [ 24379 ] {3f7e4f71-34a4-45c6-959d-e71ef85ff833} executeQuery: Code: 15. DB::Exception: Cannot rename to `value2`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53218) (comment: 01213_alter_rename_column.sql) (query 8, line 25) (in query: ALTER TABLE table_for_rename RENAME COLUMN value3 to value2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1675: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df4a1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:16:39.414435 [ 24379 ] {} TCPHandler: Code: 15. DB::Exception: Cannot rename to `value2`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1675: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df4a1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:16:39.486026 [ 24379 ] {ef90ba15-25f7-4986-b563-ccef7cd38744} executeQuery: Code: 36. DB::Exception: Cannot rename column '`value3`' to two different names in a single ALTER query. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53218) (comment: 01213_alter_rename_column.sql) (query 9, line 26) (in query: ALTER TABLE table_for_rename RENAME COLUMN value3 TO r1, RENAME COLUMN value3 TO r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1649: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9dec0c 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:16:39.487382 [ 24379 ] {} TCPHandler: Code: 36. DB::Exception: Cannot rename column '`value3`' to two different names in a single ALTER query. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1649: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9dec0c 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:16:39.559826 [ 24379 ] {545204de-9143-4047-a325-c699396a53ab} executeQuery: Code: 48. DB::Exception: Transitive renames in a single ALTER query are not allowed (don't make sense). (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53218) (comment: 01213_alter_rename_column.sql) (query 10, line 27) (in query: ALTER TABLE table_for_rename RENAME COLUMN value3 TO r1, RENAME COLUMN r1 TO value1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1647: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9dec98 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:16:39.561069 [ 24379 ] {} TCPHandler: Code: 48. DB::Exception: Transitive renames in a single ALTER query are not allowed (don't make sense). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1647: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9dec98 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:16:39.686474 [ 24379 ] {09c880e2-415d-439a-b272-cf3fb133a162} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value100` to rename. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53218) (comment: 01213_alter_rename_column.sql) (query 14, line 35) (in query: ALTER TABLE table_for_rename RENAME COLUMN value100 to renamed_value100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1669: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9dfc26 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:16:39.687332 [ 24379 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value100` to rename. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1669: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9dfc26 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:16:40.380766 [ 1859 ] {b17221d8-fa2f-44ac-aabe-b852efe5d5ab} executeQuery: Code: 36. DB::Exception: Number of aliases does not match number of projection columns. Expected 2, got 1. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53376) (comment: 03280_aliases_for_selects_and_views.sql) (query 4, line 19) (in query: SELECT a FROM ( SELECT number, number*2 FROM numbers(2) ) AS x (a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x0000000010ac9c46 4. ./build_docker/./src/Analyzer/QueryNode.cpp:60: DB::QueryNode::resolveProjectionColumns(std::vector>) @ 0x000000001797e5b4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5802: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a80ba8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a86fde 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc6d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:40.382029 [ 1859 ] {} TCPHandler: Code: 36. DB::Exception: Number of aliases does not match number of projection columns. Expected 2, got 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x0000000010ac9c46 4. ./build_docker/./src/Analyzer/QueryNode.cpp:60: DB::QueryNode::resolveProjectionColumns(std::vector>) @ 0x000000001797e5b4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5802: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a80ba8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a86fde 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc6d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:40.392384 [ 1859 ] {d8370641-cac6-4880-a24f-4a54df474824} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `c` in scope SELECT c FROM (SELECT number, number * 2 FROM numbers(2)) AS x (a, b). Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53376) (comment: 03280_aliases_for_selects_and_views.sql) (query 5, line 25) (in query: SELECT c FROM ( SELECT number, number*2 FROM numbers(2) ) as x (a, b);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:16:40.393481 [ 1859 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `c` in scope SELECT c FROM (SELECT number, number * 2 FROM numbers(2)) AS x (a, b). Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:16:40.454425 [ 1859 ] {4073a087-b33b-4fcc-ab64-7818640eb516} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `c` in scope SELECT c FROM test_view_03280. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53376) (comment: 03280_aliases_for_selects_and_views.sql) (query 10, line 39) (in query: SELECT c FROM test_view_03280;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:16:40.456229 [ 1859 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `c` in scope SELECT c FROM test_view_03280. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:16:40.549434 [ 1859 ] {195d871f-1bef-47c0-a866-d5ed35894e30} executeQuery: Code: 36. DB::Exception: Number of aliases does not match number of expressions in SELECT list. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53376) (comment: 03280_aliases_for_selects_and_views.sql) (query 12, line 43) (in query: CREATE VIEW test_view_1_03280 (a) AS SELECT 1, 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:940: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188bb209 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:16:40.550698 [ 1859 ] {} TCPHandler: Code: 36. DB::Exception: Number of aliases does not match number of expressions in SELECT list. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:940: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188bb209 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:16:40.618243 [ 1859 ] {04b68343-ce43-44e9-8816-986e9ffead23} executeQuery: Code: 36. DB::Exception: Number of aliases does not match number of projection columns. Expected 2, got 1. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53376) (comment: 03280_aliases_for_selects_and_views.sql) (query 17, line 65) (in query: WITH t (a) AS ( SELECT 1, 2 ) SELECT b FROM t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x0000000010ac9c46 4. ./build_docker/./src/Analyzer/QueryNode.cpp:60: DB::QueryNode::resolveProjectionColumns(std::vector>) @ 0x000000001797e5b4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5802: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a80ba8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a86fde 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc6d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:40.621025 [ 1859 ] {} TCPHandler: Code: 36. DB::Exception: Number of aliases does not match number of projection columns. Expected 2, got 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x0000000010ac9c46 4. ./build_docker/./src/Analyzer/QueryNode.cpp:60: DB::QueryNode::resolveProjectionColumns(std::vector>) @ 0x000000001797e5b4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5802: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a80ba8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a86fde 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc6d9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:40.629359 [ 1859 ] {5d82c5aa-fe6e-49c3-93a4-784be970f9f5} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `c` in scope WITH t (a, b) AS (SELECT 1, 2) SELECT c FROM t. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53376) (comment: 03280_aliases_for_selects_and_views.sql) (query 18, line 71) (in query: WITH t (a, b) AS ( SELECT 1, 2 ) SELECT c FROM t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:16:40.630409 [ 1859 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `c` in scope WITH t (a, b) AS (SELECT 1, 2) SELECT c FROM t. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x0000000017ac4f5c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a891c0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:16:41.647616 [ 1061 ] {} test_zyqh1o5u.alter_table1 (a7ac0d4f-7975-4b5b-bbeb-33d4d4486d55): Part /var/lib/clickhouse/store/a7a/a7ac0d4f-7975-4b5b-bbeb-33d4d4486d55/detached/all_25_25_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No count.txt in part all_30_30_0. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:1392: DB::IMergeTreeDataPart::loadRowsCount() @ 0x000000001b1f4877 5. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:851: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000001b1f0cb0 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x000000001ac7b2dd 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001ac7c441 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000001ada4421 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b725a6a 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000001acd1c9b 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001ada5429 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b1e046e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d5cdf 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2d6a10 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc4c2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:42.188724 [ 16822 ] {68305a99-aa57-4f0d-9a6d-0893ea9b1395} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53546) (comment: 03095_window_functions_qualify.sql) (query 15, line 30) (in query: SELECT number % toUInt256(2) AS key, count() FROM numbers(10) GROUP BY key WITH CUBE WITH TOTALS QUALIFY key = toNullable(toNullable(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a814b5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:16:42.190741 [ 16822 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a814b5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:16:42.199330 [ 16822 ] {8749dfb7-d9c2-4df5-a81b-fb54daed1a86} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53546) (comment: 03095_window_functions_qualify.sql) (query 16, line 32) (in query: SELECT number % 2 AS key, count(materialize(5)) IGNORE NULLS FROM numbers(10) WHERE toLowCardinality(toLowCardinality(materialize(2))) GROUP BY key WITH CUBE WITH TOTALS QUALIFY key = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a814b5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:16:42.200648 [ 16822 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a814b5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:16:42.209014 [ 16822 ] {5d908990-4b7a-4ab1-8981-087683cd4a7f} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53546) (comment: 03095_window_functions_qualify.sql) (query 17, line 34) (in query: SELECT 4, count(4) IGNORE NULLS, number % 2 AS key FROM numbers(10) GROUP BY key WITH ROLLUP WITH TOTALS QUALIFY key = materialize(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a814b5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:16:42.210666 [ 16822 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a814b5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:16:42.218140 [ 16822 ] {1e72fffd-522c-4ab4-a0cd-01fa82068528} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53546) (comment: 03095_window_functions_qualify.sql) (query 18, line 36) (in query: SELECT 3, number % toLowCardinality(2) AS key, count() IGNORE NULLS FROM numbers(10) GROUP BY key WITH ROLLUP WITH TOTALS QUALIFY key = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a814b5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:16:42.219399 [ 16822 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a814b5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:16:45.001020 [ 1059 ] {} test_zyqh1o5u.alter_table0 (88d01403-62a5-43bf-acaa-523936f3e062): Part /var/lib/clickhouse/store/88d/88d01403-62a5-43bf-acaa-523936f3e062/detached/all_51_51_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No count.txt in part all_58_58_0. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:1392: DB::IMergeTreeDataPart::loadRowsCount() @ 0x000000001b1f4877 5. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:851: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000001b1f0cb0 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x000000001ac7b2dd 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001ac7c441 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000001ada4421 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b725a6a 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000001acd1c9b 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001ada5429 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b1e046e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d5cdf 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2d6a10 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc4c2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:45.086653 [ 1808 ] {30059143-302c-47db-8f81-ed275359ddf8} executeQuery: Code: 27. DB::Exception: Cannot read input: expected a digit but got something else: In scope SELECT toModifiedJulianDay('unparsable'). (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53792) (comment: 01543_toModifiedJulianDay.sql) (query 6, line 8) (in query: SELECT toModifiedJulianDay('unparsable');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::(anonymous namespace)::readDigit(DB::ReadBuffer&) @ 0x0000000009513e8e 5. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x0000000009513a29 6. DB::GregorianDate::GregorianDate(DB::ReadBuffer&) @ 0x000000000951448c 7. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6879d 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:16:45.087900 [ 1808 ] {} TCPHandler: Code: 27. DB::Exception: Cannot read input: expected a digit but got something else: In scope SELECT toModifiedJulianDay('unparsable'). (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::(anonymous namespace)::readDigit(DB::ReadBuffer&) @ 0x0000000009513e8e 5. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x0000000009513a29 6. DB::GregorianDate::GregorianDate(DB::ReadBuffer&) @ 0x000000000951448c 7. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6879d 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:16:45.229560 [ 1808 ] {ced12bc9-9c7c-4d65-9ace-79df3c563680} executeQuery: Code: 38. DB::Exception: Invalid date, out of range (year: 1999, month: 2, day_of_month: 29).: In scope SELECT toModifiedJulianDay('1999-02-29'). (CANNOT_PARSE_DATE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53792) (comment: 01543_toModifiedJulianDay.sql) (query 7, line 9) (in query: SELECT toModifiedJulianDay('1999-02-29');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x0000000009515e8c 4. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x0000000009513d17 5. DB::GregorianDate::GregorianDate(DB::ReadBuffer&) @ 0x000000000951448c 6. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6879d 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:16:45.230827 [ 1808 ] {} TCPHandler: Code: 38. DB::Exception: Invalid date, out of range (year: 1999, month: 2, day_of_month: 29).: In scope SELECT toModifiedJulianDay('1999-02-29'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x0000000009515e8c 4. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x0000000009513d17 5. DB::GregorianDate::GregorianDate(DB::ReadBuffer&) @ 0x000000000951448c 6. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6879d 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:16:45.237834 [ 1808 ] {970cea64-caa9-475b-bb17-38109396b0ac} executeQuery: Code: 38. DB::Exception: Invalid date, out of range (year: 1999, month: 13, day_of_month: 32).: In scope SELECT toModifiedJulianDay('1999-13-32'). (CANNOT_PARSE_DATE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53792) (comment: 01543_toModifiedJulianDay.sql) (query 8, line 10) (in query: SELECT toModifiedJulianDay('1999-13-32');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x0000000009515e8c 4. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x0000000009513d17 5. DB::GregorianDate::GregorianDate(DB::ReadBuffer&) @ 0x000000000951448c 6. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6879d 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:16:45.238686 [ 1808 ] {} TCPHandler: Code: 38. DB::Exception: Invalid date, out of range (year: 1999, month: 13, day_of_month: 32).: In scope SELECT toModifiedJulianDay('1999-13-32'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x0000000009515e8c 4. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x0000000009513d17 5. DB::GregorianDate::GregorianDate(DB::ReadBuffer&) @ 0x000000000951448c 6. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6879d 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:16:47.601433 [ 16822 ] {} SettingsSanity: Sanity check: 'max_block_size' cannot be 0. Set to default value 65409 2025.07.28 06:16:47.603774 [ 16822 ] {c1b7c47d-41de-4187-a67c-1923dcc3f2e1} SettingsSanity: Sanity check: 'max_block_size' cannot be 0. Set to default value 65409 2025.07.28 06:16:47.607337 [ 16822 ] {c1b7c47d-41de-4187-a67c-1923dcc3f2e1} SettingsSanity: Sanity check: 'max_block_size' cannot be 0. Set to default value 65409 2025.07.28 06:16:48.398920 [ 1057 ] {} test_zyqh1o5u.alter_table1 (a7ac0d4f-7975-4b5b-bbeb-33d4d4486d55): Part /var/lib/clickhouse/store/a7a/a7ac0d4f-7975-4b5b-bbeb-33d4d4486d55/detached/all_73_73_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No count.txt in part all_82_82_0. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:1392: DB::IMergeTreeDataPart::loadRowsCount() @ 0x000000001b1f4877 5. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:851: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000001b1f0cb0 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x000000001ac7b2dd 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001ac7c441 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000001ada4421 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b725a6a 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000001acd1c9b 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001ada5429 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b1e046e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d5cdf 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2d6a10 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc4c2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:48.804734 [ 1057 ] {} test_zyqh1o5u.alter_table1 (a7ac0d4f-7975-4b5b-bbeb-33d4d4486d55): Part /var/lib/clickhouse/store/a7a/a7ac0d4f-7975-4b5b-bbeb-33d4d4486d55/detached/all_74_74_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_82_82_0, expected path store/a7a/a7ac0d4f-7975-4b5b-bbeb-33d4d4486d55/detached/all_74_74_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000015f2b10c 4. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001b1f2de5 5. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000001b1f092d 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x000000001ac7b2dd 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001ac7c441 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000001ada4421 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b725a6a 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000001acd1c9b 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001ada5429 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b1e046e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d5cdf 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2d6a10 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc4c2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:49.030471 [ 1066 ] {} test_zyqh1o5u.alter_table0 (88d01403-62a5-43bf-acaa-523936f3e062): Part /var/lib/clickhouse/store/88d/88d01403-62a5-43bf-acaa-523936f3e062/detached/all_82_82_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No count.txt in part all_88_88_0. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:1392: DB::IMergeTreeDataPart::loadRowsCount() @ 0x000000001b1f4877 5. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:851: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000001b1f0cb0 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x000000001ac7b2dd 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001ac7c441 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000001ada4421 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b725a6a 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000001acd1c9b 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001ada5429 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b1e046e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d5cdf 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2d6a10 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc4c2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:49.047249 [ 1054 ] {} test_zyqh1o5u.alter_table0 (88d01403-62a5-43bf-acaa-523936f3e062): Part /var/lib/clickhouse/store/88d/88d01403-62a5-43bf-acaa-523936f3e062/detached/all_80_80_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No count.txt in part all_90_90_0. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:1392: DB::IMergeTreeDataPart::loadRowsCount() @ 0x000000001b1f4877 5. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:851: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000001b1f0cb0 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x000000001ac7b2dd 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001ac7c441 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000001ada4421 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b725a6a 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000001acd1c9b 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001ada5429 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b1e046e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d5cdf 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2d6a10 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc4c2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:51.343725 [ 24374 ] {c987cdd2-2091-4fd6-8240-558f1430d515} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43770) (query 1, line 1) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001aac5622 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa683 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:16:51.348016 [ 24374 ] {} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001aac5622 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa683 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:16:51.575400 [ 1062 ] {} test_zyqh1o5u.alter_table0 (88d01403-62a5-43bf-acaa-523936f3e062): Part /var/lib/clickhouse/store/88d/88d01403-62a5-43bf-acaa-523936f3e062/detached/all_101_101_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: Marks file '/var/lib/clickhouse/store/88d/88d01403-62a5-43bf-acaa-523936f3e062/detached/all_101_101_0/data.cmrk3' doesn't exist. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartCompact.cpp:118: DB::MergeTreeDataPartCompact::loadIndexGranularityImpl(std::shared_ptr&, DB::MergeTreeIndexGranularityInfo const&, unsigned long, DB::IDataPartStorage const&, DB::MergeTreeSettings const&) @ 0x000000001b3fe9bb 5. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartCompact.cpp:150: DB::MergeTreeDataPartCompact::loadIndexGranularity() @ 0x000000001b3fede4 6. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:842: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000001b1f093f 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x000000001ac7b2dd 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001ac7c441 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000001ada4421 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b725a6a 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000001acd1c9b 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001ada5429 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b1e046e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d5cdf 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2d6a10 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc4c2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:51.576938 [ 1062 ] {} test_zyqh1o5u.alter_table0 (88d01403-62a5-43bf-acaa-523936f3e062): Part /var/lib/clickhouse/store/88d/88d01403-62a5-43bf-acaa-523936f3e062/detached/all_98_98_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_108_108_0, expected path store/88d/88d01403-62a5-43bf-acaa-523936f3e062/detached/all_98_98_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000015f2b10c 4. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001b1f2de5 5. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000001b1f092d 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x000000001ac7b2dd 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001ac7c441 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000001ada4421 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b725a6a 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000001acd1c9b 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001ada5429 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b1e046e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d5cdf 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2d6a10 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc4c2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:51.579694 [ 1062 ] {} test_zyqh1o5u.alter_table0 (88d01403-62a5-43bf-acaa-523936f3e062): Do not enqueue part all_108_108_0 for check because it's covered by drop range all_0_108_999999999_999999999 and going to be removed 2025.07.28 06:16:51.744600 [ 24374 ] {75fa59c0-fd3c-445b-bd40-cd44236dd65e} executeQuery: Code: 36. DB::Exception: Cannot parse ClickHouse version here: a.a: in attempt to set the value of setting 'compatibility' to 'a.a'. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02503_bad_compatibility_setting.sql) (query 1, line 1) (in query: set compatibility='a.a';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000b9a8700 4. ./build_docker/./src/Core/SettingsChangesHistory.cpp:32: DB::ClickHouseVersion::ClickHouseVersion(std::basic_string_view>) @ 0x00000000172e423f 5. ./build_docker/./src/Core/Settings.cpp:6374: DB::SettingsImpl::applyCompatibilitySetting(String const&) @ 0x00000000171329ed 6. ./build_docker/./src/Core/Settings.cpp:6351: DB::SettingsImpl::set(std::basic_string_view>, DB::Field const&) @ 0x000000001713265a 7. ./build_docker/./src/Core/Settings.cpp:6469: DB::Settings::set(std::basic_string_view>, DB::Field const&) @ 0x0000000017136907 8. ./build_docker/./src/Interpreters/Context.cpp:2598: DB::Context::applySettingChangeWithLock(DB::SettingChange const&, std::lock_guard const&) @ 0x00000000181a7672 9. ./build_docker/./src/Interpreters/Context.cpp:2622: DB::Context::applySettingsChanges(DB::SettingsChanges const&) @ 0x00000000181a7ebe 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:30: DB::InterpreterSetQuery::execute() @ 0x0000000018a201bb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:16:51.745692 [ 24374 ] {} TCPHandler: Code: 36. DB::Exception: Cannot parse ClickHouse version here: a.a: in attempt to set the value of setting 'compatibility' to 'a.a'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000b9a8700 4. ./build_docker/./src/Core/SettingsChangesHistory.cpp:32: DB::ClickHouseVersion::ClickHouseVersion(std::basic_string_view>) @ 0x00000000172e423f 5. ./build_docker/./src/Core/Settings.cpp:6374: DB::SettingsImpl::applyCompatibilitySetting(String const&) @ 0x00000000171329ed 6. ./build_docker/./src/Core/Settings.cpp:6351: DB::SettingsImpl::set(std::basic_string_view>, DB::Field const&) @ 0x000000001713265a 7. ./build_docker/./src/Core/Settings.cpp:6469: DB::Settings::set(std::basic_string_view>, DB::Field const&) @ 0x0000000017136907 8. ./build_docker/./src/Interpreters/Context.cpp:2598: DB::Context::applySettingChangeWithLock(DB::SettingChange const&, std::lock_guard const&) @ 0x00000000181a7672 9. ./build_docker/./src/Interpreters/Context.cpp:2622: DB::Context::applySettingsChanges(DB::SettingsChanges const&) @ 0x00000000181a7ebe 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:30: DB::InterpreterSetQuery::execute() @ 0x0000000018a201bb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:16:52.695841 [ 1051 ] {} test_zyqh1o5u.alter_table1 (a7ac0d4f-7975-4b5b-bbeb-33d4d4486d55): Part /var/lib/clickhouse/store/a7a/a7ac0d4f-7975-4b5b-bbeb-33d4d4486d55/detached/all_103_103_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No count.txt in part all_121_121_0. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:1392: DB::IMergeTreeDataPart::loadRowsCount() @ 0x000000001b1f4877 5. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:851: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000001b1f0cb0 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x000000001ac7b2dd 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001ac7c441 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000001ada4421 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b725a6a 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000001acd1c9b 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001ada5429 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b1e046e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d5cdf 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2d6a10 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc4c2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:52.886845 [ 1051 ] {} test_zyqh1o5u.alter_table1 (a7ac0d4f-7975-4b5b-bbeb-33d4d4486d55): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 481. DB::ErrnoException: Cannot set modification time to file: /var/lib/clickhouse/store/a7a/a7ac0d4f-7975-4b5b-bbeb-33d4d4486d55/detached/all_104_104_0/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x0000000010c0e8e5 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x0000000010c0e5bd 5. ./build_docker/./src/Common/filesystemHelpers.cpp:376: FS::setModificationTime(String const&, long) @ 0x0000000010c18e8b 6. ./build_docker/./src/Disks/DiskLocal.cpp:420: DB::DiskLocal::setLastModified(String const&, Poco::Timestamp const&) @ 0x000000001786582e 7. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskBase.cpp:672: DB::DataPartStorageOnDiskBase::rename(String, String, std::shared_ptr, bool, bool) @ 0x000000001b1c43fa 8. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:1909: DB::IMergeTreeDataPart::renameTo(String const&, bool) @ 0x000000001b20303e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7175: DB::MergeTreeData::Transaction::renameParts() @ 0x000000001b3721cf 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2317: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001ac7cc23 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000001ada4421 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b725a6a 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000001acd1c9b 14. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001ada5429 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b1e046e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d5cdf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2d6a10 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc4c2 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:55.137276 [ 1054 ] {} test_zyqh1o5u.alter_table0 (88d01403-62a5-43bf-acaa-523936f3e062): Part /var/lib/clickhouse/store/88d/88d01403-62a5-43bf-acaa-523936f3e062/detached/all_127_132_1/ is broken and needs manual correction. Reason: Code: 107. DB::Exception: store/88d/88d01403-62a5-43bf-acaa-523936f3e062/detached/all_127_132_1/count.txt doesn't exist: columns: columns format version: 1 4 columns: `a` UInt8 `b` Int16 `_block_number` UInt64 `_block_offset` UInt64 , getMarkSizeInBytes: 72, getMarksCount: 2, index_granularity_info: [mark_type: [adaptive: true, compressed: true, part_type: Compact], index_granularity_bytes: 19663325, fixed_index_granularity: 36470], index_granularity: [Constant(constant_granularity: 30, last_mark_granularity: 30, num_marks_without_final: 1, has_final_mark: true)], part_state: [state: Temporary, is_unexpected_local_part: false, is_frozen: false, is_duplicate: false]. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, std::filesystem::path&&) @ 0x000000001b3f0180 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartChecksum.cpp:76: DB::MergeTreeDataPartChecksum::checkSize(DB::IDataPartStorage const&, String const&) const @ 0x000000001b3f167a 5. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2154: DB::IMergeTreeDataPart::checkConsistencyBase() const @ 0x000000001b20677f 6. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2212: DB::IMergeTreeDataPart::checkConsistency(bool) const @ 0x000000001b1f6b8a 7. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:864: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000001b1f0d2e 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x000000001ac7b2dd 9. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001ac7c441 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000001ada4421 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b725a6a 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000001acd1c9b 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001ada5429 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b1e046e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d5cdf 16. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2d6a10 17. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc4c2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:55.155114 [ 16973 ] {0caf76fc-828a-4c51-928a-f62ebe23f68c} executeQuery: Code: 43. DB::Exception: Function transform has signature: transform(T, Array(T), Array(U), U) -> U; or transform(T, Array(T), Array(T)) -> T; where T and U are types: In scope SELECT transform(number, [1], [NULL]) FROM system.numbers LIMIT 1. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43950) (comment: 02542_transform_old.sql) (query 25, line 25) (in query: SELECT transform(number, [1], [null]) FROM system.numbers LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef370f2 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:16:55.156549 [ 16973 ] {} TCPHandler: Code: 43. DB::Exception: Function transform has signature: transform(T, Array(T), Array(U), U) -> U; or transform(T, Array(T), Array(T)) -> T; where T and U are types: In scope SELECT transform(number, [1], [NULL]) FROM system.numbers LIMIT 1. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef370f2 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:16:57.150267 [ 1033 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:57.151121 [ 1041 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:57.308633 [ 16822 ] {b18ac27f-6152-4af3-83bf-6e760963f03a} executeQuery: Code: 36. DB::Exception: Cannot add new database replica: provided path /clickhouse/tables/test_test_2wuzoge7/s1/local_t_l5ydey already contains some data and it does not look like Replicated database path. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:44164) (comment: 02400_create_table_on_cluster_normalization.sql) (query 9, line 23) (in query: -- Correct error code if creating database with the same path as table has create database local_t_l5ydey engine=Replicated('/clickhouse/tables/test_' || currentDatabase() || '/{shard}/local_t_l5ydey', '1', '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:647: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x00000000176bfcb2 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:533: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000176b97ff 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000176c1f8a 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000188e4ee8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af3d7 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:16:57.310494 [ 16822 ] {} TCPHandler: Code: 36. DB::Exception: Cannot add new database replica: provided path /clickhouse/tables/test_test_2wuzoge7/s1/local_t_l5ydey already contains some data and it does not look like Replicated database path. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:647: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x00000000176bfcb2 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:533: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x00000000176b97ff 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x00000000176c1f8a 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000188e4ee8 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af3d7 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:16:57.326680 [ 24374 ] {eb4af494-3b22-428b-b27e-a3fa45f423e5} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20000101_1_1_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001b5033ee 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001b7b8f90 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001b7ba642 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0108 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 . (UNFINISHED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54286) (comment: 00834_kill_mutation.sh) (query 1, line 1) (in query: ALTER TABLE kill_mutation DELETE WHERE toUInt32(s) = 1 SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000001b50357c 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001b503444 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001b7b8f90 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001b7ba642 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0108 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:16:57.329415 [ 24374 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20000101_1_1_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001b5033ee 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001b7b8f90 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001b7ba642 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0108 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000001b50357c 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001b503444 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001b7b8f90 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001b7ba642 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0108 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:16:57.399254 [ 1033 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:57.399378 [ 1041 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:57.400182 [ 1033 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:57.400420 [ 1041 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_3}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:57.798169 [ 1039 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:57.798928 [ 1039 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:57.799496 [ 1039 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_3}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:57.805667 [ 1028 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:57.806902 [ 1028 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:57.808224 [ 1028 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_3}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:16:58.009550 [ 1855 ] {2ded60f2-de1e-4ffb-9964-b29fd60b1499} executeQuery: Code: 184. DB::Exception: Aggregate function avg(number) AS number is found inside another aggregate function in query. (ILLEGAL_AGGREGATION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54318) (comment: 01764_prefer_column_name_to_alias.sql) (query 1, line 1) (in query: SELECT avg(number) AS number, max(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:287: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af2494 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:58.010927 [ 1855 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function avg(number) AS number is found inside another aggregate function in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:287: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af2494 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:58.021046 [ 1855 ] {84d0c7fd-66be-4ffc-ab6a-62565eaf6175} executeQuery: Code: 184. DB::Exception: Aggregate function sum(x) AS x is found inside another aggregate function in query. (ILLEGAL_AGGREGATION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54318) (comment: 01764_prefer_column_name_to_alias.sql) (query 2, line 2) (in query: SELECT sum(x) AS x, max(x) FROM (SELECT 1 AS x UNION ALL SELECT 2 AS x) t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:287: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af2494 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:58.022007 [ 1855 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function sum(x) AS x is found inside another aggregate function in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:287: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af2494 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:58.031989 [ 1855 ] {70aa088d-f2b1-4a3f-95ac-7288c00ba951} executeQuery: Code: 184. DB::Exception: Aggregate function sum(C1) AS C1 is found inside another aggregate function in query. (ILLEGAL_AGGREGATION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54318) (comment: 01764_prefer_column_name_to_alias.sql) (query 3, line 3) (in query: select sum(C1) as C1, count(C1) as C2 from (select number as C1 from numbers(3)) as ITBL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:287: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af2494 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:16:58.033067 [ 1855 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function sum(C1) AS C1 is found inside another aggregate function in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:287: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af2494 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:17:00.026440 [ 2114 ] {97f5996e-b130-4ebd-bee4-571377a8eea1} executeQuery: Code: 36. DB::Exception: extractGroups length of 'needle' argument must be greater than 0.: In scope SELECT extractGroups('hello', ''). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54474) (comment: 01275_extract_groups_check.sql) (query 1, line 1) (in query: SELECT extractGroups('hello', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf6575 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:00.033165 [ 2114 ] {} TCPHandler: Code: 36. DB::Exception: extractGroups length of 'needle' argument must be greater than 0.: In scope SELECT extractGroups('hello', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf6575 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:00.060586 [ 1039 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_4} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:00.066483 [ 1039 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:00.069421 [ 1039 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_4}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:00.101249 [ 1031 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_4} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:00.104057 [ 1031 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:00.106566 [ 1031 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_4}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:00.199151 [ 2114 ] {2f0b98cc-2ab4-4a77-82aa-9a626b8f4e14} executeQuery: Code: 36. DB::Exception: Length of 'needle' argument must be greater than 0.: In scope SELECT extractAllGroups('hello', ''). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54474) (comment: 01275_extract_groups_check.sql) (query 2, line 2) (in query: SELECT extractAllGroups('hello', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf4e93 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:00.200864 [ 2114 ] {} TCPHandler: Code: 36. DB::Exception: Length of 'needle' argument must be greater than 0.: In scope SELECT extractAllGroups('hello', ''). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf4e93 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:00.508784 [ 1039 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_4} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:00.510911 [ 1039 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:00.511601 [ 1035 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_4} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:00.511796 [ 1039 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_4}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:00.512556 [ 1035 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:00.513180 [ 1035 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_4}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:00.581812 [ 2114 ] {f00920b1-4641-4225-b8f5-299a0a948204} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', ' '). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54474) (comment: 01275_extract_groups_check.sql) (query 3, line 4) (in query: SELECT extractGroups('hello', ' ');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf6605 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:00.584620 [ 2114 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', ' '). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf6605 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:00.732425 [ 2114 ] {f05b036b-d802-4ad5-91fc-7a9e2a151e09} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', ' '). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54474) (comment: 01275_extract_groups_check.sql) (query 4, line 5) (in query: SELECT extractAllGroups('hello', ' ');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf4f23 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:00.733590 [ 2114 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', ' '). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf4f23 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:00.742281 [ 2114 ] {47a9f942-277f-4577-af1b-f105fc9baa80} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', '\0'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54474) (comment: 01275_extract_groups_check.sql) (query 5, line 7) (in query: SELECT extractGroups('hello', '\0');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf6605 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:00.743287 [ 2114 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', '\0'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf6605 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:00.753532 [ 2114 ] {b6220233-838b-4e9e-8b7c-3e3c4361e2ee} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', '\0'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54474) (comment: 01275_extract_groups_check.sql) (query 6, line 8) (in query: SELECT extractAllGroups('hello', '\0');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf4f23 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:00.754718 [ 2114 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', '\0'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf4f23 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:00.763689 [ 2114 ] {e5080cea-a600-4e8d-8ab7-28fe51967d63} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractGroups('hello', 'world'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54474) (comment: 01275_extract_groups_check.sql) (query 7, line 10) (in query: SELECT extractGroups('hello', 'world');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf6605 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:00.764721 [ 2114 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractGroups('hello', 'world'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf6605 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:00.772789 [ 2114 ] {7e1cf2c9-839c-49dd-bd39-d1188def4549} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractAllGroups('hello', 'world'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54474) (comment: 01275_extract_groups_check.sql) (query 8, line 11) (in query: SELECT extractAllGroups('hello', 'world');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf4f23 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:00.773860 [ 2114 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractAllGroups('hello', 'world'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf4f23 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:00.783956 [ 2114 ] {448f360b-e6c6-4866-a9f0-455d29e16067} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractGroups('hello', 'hello|world'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54474) (comment: 01275_extract_groups_check.sql) (query 9, line 13) (in query: SELECT extractGroups('hello', 'hello|world');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf6697 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:00.785113 [ 2114 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractGroups('hello', 'hello|world'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf6697 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:01.007361 [ 2114 ] {75a4ab3f-724f-4934-a6e4-7246da8d2387} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractAllGroups('hello', 'hello|world'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54474) (comment: 01275_extract_groups_check.sql) (query 10, line 14) (in query: SELECT extractAllGroups('hello', 'hello|world');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf4fb3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:01.008296 [ 2114 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractAllGroups('hello', 'hello|world'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf4fb3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:01.154323 [ 1036 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.155608 [ 1036 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.156213 [ 16819 ] {578fe5ce-fbf2-424c-87cc-e8493133e719} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutations 'mutation_4.txt, mutation_5.txt' with part '20010101_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001b5033ee 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001b7b8f90 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001b7ba642 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0108 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 . (UNFINISHED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54516) (comment: 00834_kill_mutation.sh) (query 1, line 1) (in query: ALTER TABLE kill_mutation DELETE WHERE x = 1 SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000001b50357c 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001b503444 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001b7b8f90 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001b7ba642 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0108 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:17:01.156692 [ 1036 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_5}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.158404 [ 16819 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutations 'mutation_4.txt, mutation_5.txt' with part '20010101_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001b5033ee 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001b7b8f90 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001b7ba642 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0108 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x000000001b50357c 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000001b503444 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000001b7b8f90 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000001b7ba642 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000188a0108 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:17:01.161690 [ 1034 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.162791 [ 1034 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.163792 [ 1034 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_5}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.515171 [ 1040 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.516015 [ 1040 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.516780 [ 1040 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_5}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.519466 [ 1038 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.520174 [ 1038 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.520773 [ 1038 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_5}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.880080 [ 1037 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.883254 [ 1041 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.883589 [ 1037 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.883903 [ 1041 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.884455 [ 1037 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_5}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:01.884481 [ 1041 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_5}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:02.287733 [ 1035 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:02.288951 [ 1035 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:02.290047 [ 1035 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20000101_1_1_0_5}: Code: 6. DB::Exception: Cannot parse string 'a' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:02.290487 [ 1042 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_5} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:02.291288 [ 1042 ] {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_5} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:02.291913 [ 1042 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {786d0115-d49f-4d27-b428-738c98e0fcac::20010101_2_2_0_5}: Code: 6. DB::Exception: Cannot parse string 'b' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toUInt32(s :: 0) -> toUInt32(__table1.s) UInt32 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001c0b6688 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001c0b6517 16. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:229: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000018a83f9a 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000001b62611f 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000001b625291 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000001b8074b4 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:17:03.980574 [ 16973 ] {013d1416-a6b0-4b14-933d-b9b00a8d2331} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e') AS v, toTypeName(v). (UNKNOWN_SETTING) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54702) (comment: 01418_custom_settings.sql) (query 23, line 26) (in query: SELECT getSetting('custom_e') as v, toTypeName(v);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Core/BaseSettings.cpp:53: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x0000000016feddb9 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::get(std::basic_string_view>) const @ 0x00000000172b71ee 6. ./build_docker/./src/Core/Settings.cpp:6464: DB::Settings::get(std::basic_string_view>) const @ 0x000000001713689a 7. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000000ac98fd6 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac98e69 9. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:17:03.983760 [ 16973 ] {} TCPHandler: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e') AS v, toTypeName(v). (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Core/BaseSettings.cpp:53: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x0000000016feddb9 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::get(std::basic_string_view>) const @ 0x00000000172b71ee 6. ./build_docker/./src/Core/Settings.cpp:6464: DB::Settings::get(std::basic_string_view>) const @ 0x000000001713689a 7. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000000ac98fd6 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac98e69 9. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:17:04.142743 [ 16973 ] {128a2af0-b2aa-4b58-a900-35f9ce0ec45c} executeQuery: Code: 115. DB::Exception: Setting invalid_custom is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings. (UNKNOWN_SETTING) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54702) (comment: 01418_custom_settings.sql) (query 27, line 31) (in query: SET invalid_custom = 8;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/AccessControl.cpp:134: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x0000000016c832d2 5. ./build_docker/./src/Access/AccessControl.cpp:689: DB::AccessControl::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x0000000016c817fa 6. ./build_docker/./src/Access/SettingsConstraints.cpp:279: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff06 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016e40223 8. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000181a89f6 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000018a200ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:17:04.143936 [ 16973 ] {} TCPHandler: Code: 115. DB::Exception: Setting invalid_custom is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings. (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/AccessControl.cpp:134: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x0000000016c832d2 5. ./build_docker/./src/Access/AccessControl.cpp:689: DB::AccessControl::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x0000000016c817fa 6. ./build_docker/./src/Access/SettingsConstraints.cpp:279: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff06 7. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016e40223 8. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000181a89f6 9. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000018a200ec 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:17:04.334015 [ 16973 ] {c554a400-3d90-4daa-9f97-09ca354ff2bc} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_f': In scope SELECT getSetting('custom_f') AS v, toTypeName(v). (UNKNOWN_SETTING) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54702) (comment: 01418_custom_settings.sql) (query 35, line 41) (in query: SELECT getSetting('custom_f') as v, toTypeName(v);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Core/BaseSettings.cpp:53: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x0000000016feddb9 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::get(std::basic_string_view>) const @ 0x00000000172b71ee 6. ./build_docker/./src/Core/Settings.cpp:6464: DB::Settings::get(std::basic_string_view>) const @ 0x000000001713689a 7. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000000ac98fd6 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac98e69 9. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:17:04.335544 [ 16973 ] {} TCPHandler: Code: 115. DB::Exception: Unknown setting 'custom_f': In scope SELECT getSetting('custom_f') AS v, toTypeName(v). (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Core/BaseSettings.cpp:53: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x0000000016feddb9 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::get(std::basic_string_view>) const @ 0x00000000172b71ee 6. ./build_docker/./src/Core/Settings.cpp:6464: DB::Settings::get(std::basic_string_view>) const @ 0x000000001713689a 7. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000000ac98fd6 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac98e69 9. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:17:06.280451 [ 1859 ] {3944b980-467f-418e-b6bc-c7ebf2798b45} executeQuery: Code: 42. DB::Exception: Number of arguments for function locate doesn't match: passed 0, should be 2 or 3: In scope SELECT locate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54854) (comment: 00765_locate.sql) (query 3, line 4) (in query: SELECT locate();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000087e9026 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cab7090 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:06.281566 [ 1859 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function locate doesn't match: passed 0, should be 2 or 3: In scope SELECT locate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000087e9026 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cab7090 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:06.429331 [ 1859 ] {7f252cba-e4c1-4957-87a5-f8f6cced73d8} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate(1, 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54854) (comment: 00765_locate.sql) (query 4, line 5) (in query: SELECT locate(1, 'abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cab715f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:06.430466 [ 1859 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate(1, 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cab715f 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:06.592848 [ 1859 ] {a535345f-bf4f-4f46-bc15-f9db0fd3e8c7} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate('abc', 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54854) (comment: 00765_locate.sql) (query 5, line 6) (in query: SELECT locate('abc', 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cab722c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:06.593994 [ 1859 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate('abc', 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cab722c 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:06.727464 [ 1859 ] {0e47ca8a-3674-458b-9f37-979d1f92d402} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate('abc', 'abc', 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54854) (comment: 00765_locate.sql) (query 6, line 7) (in query: SELECT locate('abc', 'abc', 'abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cab72ef 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:06.728507 [ 1859 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate('abc', 'abc', 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cab72ef 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:06.866448 [ 2054 ] {66a0a0d0-77c4-4dcd-9738-1e09ebedc57a} executeQuery: Code: 277. DB::Exception: Index `idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54870) (comment: 03047_on_fly_mutations_skip_index.sql) (query 12, line 24) (in query: SELECT id, v FROM t_lightweight_mut_3 WHERE v > 100 ORDER BY id SETTINGS force_data_skipping_indices = 'idx';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:663: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000001b450232 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b2441 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3bb568 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:17:06.867910 [ 2054 ] {} TCPHandler: Code: 277. DB::Exception: Index `idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:663: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000001b450232 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001c3b2441 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001c3b0b69 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001c3b07f0 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3bb568 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001c3280c6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36dd22 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:17:07.474936 [ 1808 ] {a0fb0c36-bbd1-4ddc-838d-453032c987ca} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, Array(Nothing) because some of them are Array and some of them are not: In scope SELECT hasAny([['Hello, world']], [[[]]]). (NO_COMMON_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55344) (comment: 00918_has_unsufficient_type_check.sql) (query 1, line 1) (in query: SELECT hasAny([['Hello, world']], [[[]]]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dfec5c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000174fb740 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000175001b3 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000174fe81f 7. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000174fe81f 8. DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000105e8567 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:17:07.476813 [ 1808 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, Array(Nothing) because some of them are Array and some of them are not: In scope SELECT hasAny([['Hello, world']], [[[]]]). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dfec5c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000174fb740 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000175001b3 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000174fe81f 7. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000174fe81f 8. DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000105e8567 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:17:07.660263 [ 16819 ] {f5b02932-d609-4ca8-a6dc-66f6713c0d98} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON * join expression expected function. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55374) (comment: 03246_join_on_asterisk.sql) (query 3, line 5) (in query: SELECT 1 FROM t0 JOIN t0 ON *;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Planner/PlannerJoinsLogical.cpp:512: DB::buildJoinStepLogical(DB::Block const&, DB::Block const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000189e7a1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2061: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b118b 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:17:07.661645 [ 16819 ] {} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON * join expression expected function. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Planner/PlannerJoinsLogical.cpp:512: DB::buildJoinStepLogical(DB::Block const&, DB::Block const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000189e7a1c 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2061: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b118b 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:17:07.807462 [ 16819 ] {6d547c0a-3f7c-4e4a-a0b9-fa670b1bbdf8} executeQuery: Code: 43. DB::Exception: Illegal type (Tuple(Int32, Int32)) of 1 argument of function and. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55374) (comment: 03246_join_on_asterisk.sql) (query 4, line 6) (in query: SELECT 1 FROM t0 JOIN t0 ON (*,);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x00000000087f794c 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000015f8d021 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:329: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000179c73a9 11. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:249: DB::toBoolIfNeeded(DB::JoinActionRef, DB::ActionsDAG&, std::shared_ptr const&) @ 0x000000001c342d92 12. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:264: DB::concatConditionsWithFunction(std::vector> const&, std::unique_ptr> const&, std::shared_ptr const&) @ 0x000000001c343398 13. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:276: DB::concatConditions(std::vector> const&, std::unique_ptr> const&) @ 0x000000001c3437db 14. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:281: DB::concatMergeConditions(std::vector>&, std::unique_ptr> const&) @ 0x000000001c3438b5 15. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:632: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c34804f 16. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 17. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:17:07.809559 [ 16819 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Tuple(Int32, Int32)) of 1 argument of function and. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x00000000087f794c 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000015f8d021 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:329: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000179c73a9 11. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:249: DB::toBoolIfNeeded(DB::JoinActionRef, DB::ActionsDAG&, std::shared_ptr const&) @ 0x000000001c342d92 12. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:264: DB::concatConditionsWithFunction(std::vector> const&, std::unique_ptr> const&, std::shared_ptr const&) @ 0x000000001c343398 13. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:276: DB::concatConditions(std::vector> const&, std::unique_ptr> const&) @ 0x000000001c3437db 14. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:281: DB::concatMergeConditions(std::vector>&, std::unique_ptr> const&) @ 0x000000001c3438b5 15. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:632: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c34804f 16. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 17. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:17:07.920971 [ 16819 ] {a7a0f4a0-5565-4546-bc39-e2998a7ab264} executeQuery: Code: 36. DB::Exception: JOIN INNER JOIN ... USING (*) USING clause expected identifier. Actual *. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55374) (comment: 03246_join_on_asterisk.sql) (query 5, line 7) (in query: SELECT 1 FROM t0 JOIN t0 USING *;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5164: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017ac0601 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc538 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:17:07.923022 [ 16819 ] {} TCPHandler: Code: 36. DB::Exception: JOIN INNER JOIN ... USING (*) USING clause expected identifier. Actual *. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5164: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017ac0601 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc538 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:17:08.072176 [ 24374 ] {a203427e-ab8d-494b-a502-747fce21ff84} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUInt64(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55384) (comment: 02810_convert_uuid_to_uint128.sql) (query 4, line 4) (in query: SELECT toUInt64(toUUID('00000000-0000-0000-0000-000000000000'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1716: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000162438fd 5. ./src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cf8a4 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:17:08.073575 [ 24374 ] {} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUInt64(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1716: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000162438fd 5. ./src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cf8a4 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:17:08.272234 [ 24374 ] {a9514407-3114-4b01-b726-b515e7a014b5} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toInt128(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55384) (comment: 02810_convert_uuid_to_uint128.sql) (query 5, line 5) (in query: SELECT toInt128(toUUID('00000000-0000-0000-0000-000000000000'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1716: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToInt128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001628a09d 5. ./src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d8afa 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f8487 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f7a20 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:17:08.273479 [ 24374 ] {} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toInt128(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1716: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToInt128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001628a09d 5. ./src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d8afa 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f8487 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f7a20 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:17:08.358522 [ 16819 ] {1479945d-ad94-4e0c-880e-8db36f11e67c} executeQuery: Code: 62. DB::Exception: Invalid qualified name: a. (SYNTAX_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55414) (comment: 01372_remote_table_function_empty_table.sql) (query 1, line 1) (in query: SELECT * FROM remote('127..2', 'a.');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Core/QualifiedTableName.cpp:26: DB::QualifiedTableName::parseFromString(String const&) @ 0x000000001702f945 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:179: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000013c8baaa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8aad6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:17:08.359764 [ 16819 ] {} TCPHandler: Code: 62. DB::Exception: Invalid qualified name: a. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Core/QualifiedTableName.cpp:26: DB::QualifiedTableName::parseFromString(String const&) @ 0x000000001702f945 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:179: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000013c8baaa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8aad6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:17:10.686922 [ 1859 ] {f09db8b1-7596-429b-bee2-6d50d446377f} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55548) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:17:10.689435 [ 1859 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:11.280435 [ 2095 ] {c0ec76d1-056a-42ca-8e1e-7f3ede415a61} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55586) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:17:11.282880 [ 2095 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:11.940216 [ 24379 ] {b6359a11-c4ca-4767-99bc-4204c4ad01ce} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55650) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:17:11.942504 [ 24379 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:12.035031 [ 1860 ] {342d7def-33dc-4330-a49e-b5e1dae97ca9} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.f : 0, 1048575_UInt32 :: 1) -> plus(__table1.f, 1048575_UInt32) Decimal(38, 38) : 5'. (DECIMAL_OVERFLOW) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55636) (comment: 01732_bigint_ubsan.sql) (query 5, line 10) (in query: SELECT f + 1048575, f - 21, f - 84, f * 21, f * -21, f / 21, f / 84 FROM decimal WHERE f > 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, true>::applyScaled(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000dffb8f3 5. void DB::impl_::DecimalBinaryOperation>, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000e0e75d9 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::ColumnDecimal>>, DB::ColumnVector>(DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal>> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e209d9b 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e209681 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e20657b 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e151836 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e14c493 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e14a0ad 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e14883e 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:17:12.037167 [ 1860 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.f : 0, 1048575_UInt32 :: 1) -> plus(__table1.f, 1048575_UInt32) Decimal(38, 38) : 5'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, true>::applyScaled(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000dffb8f3 5. void DB::impl_::DecimalBinaryOperation>, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000e0e75d9 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::ColumnDecimal>>, DB::ColumnVector>(DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal>> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e209d9b 7. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e209681 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e20657b 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e151836 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e14c493 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e14a0ad 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e14883e 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:12.158782 [ 1860 ] {e2ae578a-7a75-4bae-8255-5d28748d1978} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.f : 0, -2_Int8 :: 1) -> plus(__table1.f, -2_Int8) Decimal(38, 38) : 6'. (DECIMAL_OVERFLOW) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55636) (comment: 01732_bigint_ubsan.sql) (query 6, line 11) (in query: SELECT f + -2, f - 21, f - 84, f * 21, f * -21, f / 9223372036854775807, f / 84 FROM decimal WHERE f > 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, true>::applyScaled(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000dffb8f3 5. void DB::impl_::DecimalBinaryOperation>, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000e0e75d9 6. _ZNK2DB24FunctionBinaryArithmeticINS_8PlusImplENS_8NamePlusELb1ELb1ELb0EE25executeNumericWithDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIDB8_EESB_SB_SE_NS_13ColumnDecimalISA_EENS_12ColumnVectorISD_EEEEN3COWINS_7IColumnEE13immutable_ptrISK_EERKT2_RKT3_PKNS_11ColumnConstESW_PKT4_PKT5_mPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEE @ 0x000000000e20cc5f 7. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber<_BitInt(8)>>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e20c501 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e2069fb 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e151836 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e14c493 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e14a0ad 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e14883e 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:17:12.160631 [ 1860 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.f : 0, -2_Int8 :: 1) -> plus(__table1.f, -2_Int8) Decimal(38, 38) : 6'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. wide::integer<128ul, int> DB::impl_::DecimalBinaryOperation>, true>::applyScaled(wide::integer<128ul, int>, wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000dffb8f3 5. void DB::impl_::DecimalBinaryOperation>, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>, wide::integer<128ul, int>>(DB::PODArray>, 4096ul, Allocator, 63ul, 64ul> const&, wide::integer<128ul, int> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000e0e75d9 6. _ZNK2DB24FunctionBinaryArithmeticINS_8PlusImplENS_8NamePlusELb1ELb1ELb0EE25executeNumericWithDecimalINS_15DataTypeDecimalINS_7DecimalIN4wide7integerILm128EiEEEEEENS_14DataTypeNumberIDB8_EESB_SB_SE_NS_13ColumnDecimalISA_EENS_12ColumnVectorISD_EEEEN3COWINS_7IColumnEE13immutable_ptrISK_EERKT2_RKT3_PKNS_11ColumnConstESW_PKT4_PKT5_mPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEE @ 0x000000000e20cc5f 7. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber<_BitInt(8)>>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e20c501 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e2069fb 9. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000e151836 10. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000e14c493 11. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e14a0ad 12. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e14883e 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:12.521936 [ 2095 ] {43c154ce-1dea-4bf6-be8e-093513fa9c39} executeQuery: Code: 44. DB::Exception: Illegal column '01GWJWKW30MFPQJRYEAF4XFZ9' of argument of function ULIDStringToDateTime, ULID must be 26 characters long: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9', 'America/Costa_Rica'). (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55658) (comment: 02668_ulid_decoding.sql) (query 4, line 6) (in query: SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9', 'America/Costa_Rica');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, unsigned long const&) @ 0x00000000088d14cc 4. DB::FunctionULIDStringToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088da079 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:12.523501 [ 2095 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column '01GWJWKW30MFPQJRYEAF4XFZ9' of argument of function ULIDStringToDateTime, ULID must be 26 characters long: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9', 'America/Costa_Rica'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, unsigned long const&) @ 0x00000000088d14cc 4. DB::FunctionULIDStringToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088da079 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:12.629427 [ 24373 ] {14fba4cf-58dc-47d2-8173-8f519c358736} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55688) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:17:12.631538 [ 24373 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:12.653615 [ 2095 ] {030d247b-67b1-47df-afe7-deeee440e4cc} executeQuery: Code: 36. DB::Exception: Cannot load time zone America/Costa_Ric: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E', 'America/Costa_Ric'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55658) (comment: 02668_ulid_decoding.sql) (query 5, line 7) (in query: SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E', 'America/Costa_Ric');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000001741d2bd 8. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int const&, String&, 0>(std::allocator const&, unsigned int const&, String&) @ 0x00000000088db4b5 9. DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x00000000088da4d2 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:17:12.654763 [ 2095 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone America/Costa_Ric: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E', 'America/Costa_Ric'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000001741d2bd 8. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int const&, String&, 0>(std::allocator const&, unsigned int const&, String&) @ 0x00000000088db4b5 9. DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x00000000088da4d2 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:17:12.661986 [ 2095 ] {d2304135-e00d-43e8-bf44-260d6c068db7} executeQuery: Code: 44. DB::Exception: Illegal column '01GWJWKW30MFPQJRYEAF4XFZ9E0' of argument of function ULIDStringToDateTime, ULID must be 26 characters long: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E0'). (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55658) (comment: 02668_ulid_decoding.sql) (query 6, line 8) (in query: SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E0');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, unsigned long const&) @ 0x00000000088d14cc 4. DB::FunctionULIDStringToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088da079 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:12.662962 [ 2095 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column '01GWJWKW30MFPQJRYEAF4XFZ9E0' of argument of function ULIDStringToDateTime, ULID must be 26 characters long: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E0'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, unsigned long const&) @ 0x00000000088d14cc 4. DB::FunctionULIDStringToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000088da079 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:12.783990 [ 2095 ] {21376ebf-ef61-4220-9427-efbfe098c8ac} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55658) (comment: 02668_ulid_decoding.sql) (query 7, line 9) (in query: SELECT ULIDStringToDateTime(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x00000000088da72b 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:17:12.785215 [ 2095 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x00000000088da72b 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:17:12.792189 [ 2095 ] {80ad54c4-f992-4ea3-9811-6918f90a3a99} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime(1, 2). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55658) (comment: 02668_ulid_decoding.sql) (query 8, line 10) (in query: SELECT ULIDStringToDateTime(1, 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x00000000088da72b 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:17:12.793092 [ 2095 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime(1, 2). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x00000000088da72b 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:17:13.337854 [ 24373 ] {910167b5-7213-4011-9c33-58bf3818b12f} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55740) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:17:13.340159 [ 24373 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:13.590869 [ 1808 ] {21f52b93-2601-41b7-b79a-b646850a924b} executeQuery: Code: 80. DB::Exception: Failed to rewrite ' test_0509diln.t1 AS __table1 ALL INNER JOIN test_0509diln.t2 AS __table2 ON __table1.a = if(__table2.b > 0, __table2.a, 0), (SELECT __table4.a AS x FROM test_0509diln.t3 AS __table4 WHERE (__table4.a + 1) = __table4.b) AS __table3' to INNER JOIN: no equi-join conditions found in WHERE clause. You may set setting `cross_to_inner_join_rewrite` to `1` to allow slow CROSS JOIN for this case. (INCORRECT_QUERY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55710) (comment: 02564_analyzer_cross_to_inner.sql) (query 31, line 84) (in query: -- { echoOff } SELECT * FROM t1, t2, (SELECT a as x from t3 where a + 1 = b ) as t3 WHERE t1.a = if(t2.b > 0, t2.a, 0) SETTINGS cross_to_inner_join_rewrite = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:355: DB::(anonymous namespace)::CrossToInnerJoinVisitor::checkNotRewritten(bool, std::shared_ptr const&) @ 0x0000000017ef369a 5. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:282: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x0000000017ef1ee8 6. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:392: DB::CrossToInnerJoinPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017eeeff8 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:17:13.592292 [ 1808 ] {} TCPHandler: Code: 80. DB::Exception: Failed to rewrite ' test_0509diln.t1 AS __table1 ALL INNER JOIN test_0509diln.t2 AS __table2 ON __table1.a = if(__table2.b > 0, __table2.a, 0), (SELECT __table4.a AS x FROM test_0509diln.t3 AS __table4 WHERE (__table4.a + 1) = __table4.b) AS __table3' to INNER JOIN: no equi-join conditions found in WHERE clause. You may set setting `cross_to_inner_join_rewrite` to `1` to allow slow CROSS JOIN for this case. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:355: DB::(anonymous namespace)::CrossToInnerJoinVisitor::checkNotRewritten(bool, std::shared_ptr const&) @ 0x0000000017ef369a 5. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:282: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x0000000017ef1ee8 6. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:392: DB::CrossToInnerJoinPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017eeeff8 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:17:14.017331 [ 24373 ] {9729f148-2c79-4ea6-8069-93f568a3a015} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55776) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:17:14.020263 [ 24373 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:14.731139 [ 24374 ] {a861ecff-1225-4afc-8d78-72d6703237a6} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55812) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:17:14.735970 [ 24374 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:15.407303 [ 1851 ] {0e847839-45f9-4f8c-ba52-03928b01ef9c} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55874) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:17:15.410123 [ 1851 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:16.104143 [ 1851 ] {b47554f1-be06-43e9-963a-220b77b8e55e} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55926) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:17:16.108511 [ 1851 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:16.747204 [ 1851 ] {2ffea3ad-6329-4984-a07a-4a2f62032075} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55948) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:17:16.749561 [ 1851 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000cd9c858 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d030215 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02d8f0 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000d02ca6b 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d027ef3 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d026906 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0258de 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:20.891039 [ 16973 ] {6645dfce-96b3-4164-8a53-565ebd7f8593} executeQuery: Code: 36. DB::Exception: Cannot load time zone /abc: In scope SELECT toDateTime(0, '/abc'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40886) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (query 1, line 1) (in query: select toDateTime(0, '/abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000001741c966 8. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x000000000950c886 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000016203793 10. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000162db629 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016202ee4 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000016203062 13. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 14. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 15. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 16. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:17:20.892648 [ 16973 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone /abc: In scope SELECT toDateTime(0, '/abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000001741c966 8. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x000000000950c886 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000016203793 10. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000162db629 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016202ee4 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000016203062 13. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 14. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 15. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 16. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:17:20.909002 [ 16973 ] {e9eeb92c-4601-4646-96ca-4c00099987e8} executeQuery: Code: 36. DB::Exception: Cannot load time zone ./abc: In scope SELECT toDateTime(0, './abc'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40886) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (query 2, line 2) (in query: select toDateTime(0, './abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000001741c966 8. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x000000000950c886 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000016203793 10. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000162db629 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016202ee4 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000016203062 13. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 14. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 15. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 16. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:17:20.910321 [ 16973 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone ./abc: In scope SELECT toDateTime(0, './abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000001741c966 8. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x000000000950c886 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000016203793 10. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000162db629 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016202ee4 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000016203062 13. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 14. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 15. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 16. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:17:20.924133 [ 16973 ] {28092b46-cf59-4649-9f5a-c679692be1da} executeQuery: Code: 36. DB::Exception: Cannot load time zone ../abc: In scope SELECT toDateTime(0, '../abc'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40886) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (query 3, line 3) (in query: select toDateTime(0, '../abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000001741c966 8. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x000000000950c886 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000016203793 10. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000162db629 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016202ee4 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000016203062 13. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 14. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 15. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 16. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:17:20.925551 [ 16973 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone ../abc: In scope SELECT toDateTime(0, '../abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000001741c966 8. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x000000000950c886 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000016203793 10. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000162db629 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016202ee4 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000016203062 13. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 14. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 15. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 16. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:17:20.936236 [ 16973 ] {56d5ada1-c5e5-424c-bb41-a17792d186e7} executeQuery: Code: 36. DB::Exception: Cannot load time zone ~/abc: In scope SELECT toDateTime(0, '~/abc'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40886) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (query 4, line 4) (in query: select toDateTime(0, '~/abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000001741c966 8. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x000000000950c886 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000016203793 10. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000162db629 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016202ee4 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000016203062 13. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 14. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 15. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 16. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:17:20.938348 [ 16973 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone ~/abc: In scope SELECT toDateTime(0, '~/abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000001741c966 8. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x000000000950c886 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000016203793 10. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000162db629 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016202ee4 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000016203062 13. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 14. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 15. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 16. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:17:20.949614 [ 16973 ] {fef20f77-3875-4e78-a5c0-a6c6790b8765} executeQuery: Code: 36. DB::Exception: Cannot load time zone abc/../../cba: In scope SELECT toDateTime(0, 'abc/../../cba'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40886) (comment: 02505_forbid_paths_in_datetime_timezone.sql) (query 5, line 5) (in query: select toDateTime(0, 'abc/../../cba');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000001741c966 8. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x000000000950c886 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000016203793 10. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000162db629 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016202ee4 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000016203062 13. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 14. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 15. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 16. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:17:20.950937 [ 16973 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone abc/../../cba: In scope SELECT toDateTime(0, 'abc/../../cba'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000001741c966 8. std::shared_ptr std::allocate_shared[abi:ne190107], String, 0>(std::allocator const&, String&&) @ 0x000000000950c886 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000016203793 10. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000162db629 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016202ee4 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x0000000016203062 13. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 14. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 15. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 16. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:17:33.961588 [ 24374 ] {e64011c7-35fd-4e71-96a9-35c43795eb76} executeQuery: Code: 561. DB::Exception: ZSTD stream decoding failed: error 'Frame requires too much memory for decoding'; ZSTD version: 1.5.7: While reading from: /var/lib/clickhouse/user_files/test_02961_1753694243995397.csv: (while reading header): (in file/uri /var/lib/clickhouse/user_files/test_02961_1753694243995397.csv): While executing CSVRowInputFormat: While executing File. (ZSTD_DECODER_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56874) (comment: 02961_output_format_compress_params.sh) (query 1, line 1) (in query: SELECT count() FROM file('test_02961_1753694243995397.csv', 'CSV', 'x UInt64', 'zstd') SETTINGS zstd_window_log_max = 29;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, char const (&) [6], String&&) @ 0x0000000010c61974 4. ./build_docker/./src/IO/ZstdInflatingReadBuffer.cpp:63: DB::ZstdInflatingReadBuffer::nextImpl() @ 0x0000000010c61735 5. DB::ReadBuffer::next() @ 0x0000000008915c7b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x0000000010c58e76 7. DB::ReadBuffer::next() @ 0x0000000008915c7b 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001bdfea37 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000001bdbcff8 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x000000001aac38e3 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:17:33.966055 [ 24374 ] {} TCPHandler: Code: 561. DB::Exception: ZSTD stream decoding failed: error 'Frame requires too much memory for decoding'; ZSTD version: 1.5.7: While reading from: /var/lib/clickhouse/user_files/test_02961_1753694243995397.csv: (while reading header): (in file/uri /var/lib/clickhouse/user_files/test_02961_1753694243995397.csv): While executing CSVRowInputFormat: While executing File. (ZSTD_DECODER_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, char const (&) [6], String&&) @ 0x0000000010c61974 4. ./build_docker/./src/IO/ZstdInflatingReadBuffer.cpp:63: DB::ZstdInflatingReadBuffer::nextImpl() @ 0x0000000010c61735 5. DB::ReadBuffer::next() @ 0x0000000008915c7b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x0000000010c58e76 7. DB::ReadBuffer::next() @ 0x0000000008915c7b 8. ./src/IO/ReadBuffer.h:96: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001bdfea37 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000001bdbcff8 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 11. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 12. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 17. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x000000001aac38e3 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:35.741720 [ 1860 ] {0d474ebb-f44e-4ef6-a60d-8d3cf527373d} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (16) of function h3ToChildren is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToChildren(599405990164561919, 16). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56968) (comment: 01070_h3_to_children.sql) (query 1, line 3) (in query: SELECT h3ToChildren(599405990164561919, 16);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::(anonymous namespace)::FunctionH3ToChildren::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9761c7 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:35.743112 [ 1860 ] {} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (16) of function h3ToChildren is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToChildren(599405990164561919, 16). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::(anonymous namespace)::FunctionH3ToChildren::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9761c7 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:36.882572 [ 1860 ] {2adec4bf-5119-4529-a5c5-80689531f21f} executeQuery: Code: 386. DB::Exception: There is no supertype for types Tuple(Array(UInt8), UInt8), Tuple(Array(UInt8), UInt8, String, String, UInt8) because Tuples have different sizes: In scope SELECT if(xxx = 'x', ([2], 3), ([3], 4, 'q', 'w', 7)) FROM agg_table. (NO_COMMON_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57014) (comment: 01701_if_tuple_segfault.sql) (query 6, line 21) (in query: SELECT if(xxx = 'x', ([2], 3), ([3], 4, 'q', 'w', 7)) FROM agg_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dfec5c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000174fb740 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:387: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000001750017e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017b715e2 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:36.883993 [ 1860 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Tuple(Array(UInt8), UInt8), Tuple(Array(UInt8), UInt8, String, String, UInt8) because Tuples have different sizes: In scope SELECT if(xxx = 'x', ([2], 3), ([3], 4, 'q', 'w', 7)) FROM agg_table. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dfec5c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000174fb740 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:387: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000001750017e 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017b715e2 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:38.905695 [ 1808 ] {f404caf5-a96c-47f2-be78-a77be2f332d1} executeQuery: Code: 36. DB::Exception: Bad format %X in function printf with 123.123 Float64 Const(size = 1, Float64(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%X: %X', 123.123). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45426) (comment: 03203_function_printf.sql) (query 30, line 45) (in query: select printf('%%X: %X', 123.123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000ea56954 4. DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea52dcd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:38.908732 [ 1808 ] {} TCPHandler: Code: 36. DB::Exception: Bad format %X in function printf with 123.123 Float64 Const(size = 1, Float64(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%X: %X', 123.123). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000ea56954 4. DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea52dcd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:38.916324 [ 1808 ] {4ade33ac-7fb1-4f35-80fa-25abfab08834} executeQuery: Code: 36. DB::Exception: Bad format %A in function printf with 'abc' String Const(size = 1, String(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%A: %A', 'abc'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45426) (comment: 03203_function_printf.sql) (query 31, line 46) (in query: select printf('%%A: %A', 'abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000ea56954 4. DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea52dcd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:38.917382 [ 1808 ] {} TCPHandler: Code: 36. DB::Exception: Bad format %A in function printf with 'abc' String Const(size = 1, String(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%A: %A', 'abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000ea56954 4. DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea52dcd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:38.923771 [ 1808 ] {d2ab43b8-3949-48a6-b8aa-10b464b9a996} executeQuery: Code: 36. DB::Exception: Bad format %s in function printf with 100 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%s: %s', 100). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45426) (comment: 03203_function_printf.sql) (query 32, line 47) (in query: select printf('%%s: %s', 100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000ea56954 4. DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea52dcd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:38.924930 [ 1808 ] {} TCPHandler: Code: 36. DB::Exception: Bad format %s in function printf with 100 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%s: %s', 100). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000ea56954 4. DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea52dcd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:38.930687 [ 1808 ] {6d185ac1-bf35-45fd-b22d-8cb73550049f} executeQuery: Code: 36. DB::Exception: Bad format %n in function printf with 100 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%n: %n', 100). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45426) (comment: 03203_function_printf.sql) (query 33, line 48) (in query: select printf('%%n: %n', 100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000ea56954 4. DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea52dcd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:38.931713 [ 1808 ] {} TCPHandler: Code: 36. DB::Exception: Bad format %n in function printf with 100 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%n: %n', 100). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000ea56954 4. DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea52dcd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:38.937829 [ 1808 ] {c7016692-f2a2-4623-8a10-76e7e424db52} executeQuery: Code: 36. DB::Exception: Bad format %f in function printf with 0 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%f: %f', 0). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45426) (comment: 03203_function_printf.sql) (query 34, line 49) (in query: select printf('%%f: %f', 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000ea56954 4. DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea52dcd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:38.939198 [ 1808 ] {} TCPHandler: Code: 36. DB::Exception: Bad format %f in function printf with 0 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%f: %f', 0). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000ea56954 4. DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea52dcd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:46.365610 [ 1867 ] {97d56fb3-222d-47e2-ac29-44f4bde8323c} executeQuery: Code: 10. DB::Exception: Not found column toUInt128(__table2.id): in block __table2.id UUID UUID(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45804) (comment: 03393_join_bug_77848.sql) (query 8, line 11) (in query: -- TODO(@vdimir): NOT_FOUND_COLUMN_IN_BLOCK is a bug, should be fixed -- This tests ensures that query does not crash at least SELECT 1 FROM BadTable i LEFT JOIN BadJoin c ON i.id_uint = toUInt128(c.id) WHERE equals(i.id_uint, 12);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:977: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d2fad 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 6. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000001c0b4ee0 7. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000001c321a81 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&&, bool&) @ 0x000000001895ff08 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:155: DB::QueryPlanOptimizations::addNewFilterStepOrThrow(DB::QueryPlan::Node*, std::list>&, DB::ActionsDAG, bool, unsigned long, bool) @ 0x000000001c4a94e2 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:399: DB::QueryPlanOptimizations::tryPushDownOverJoinStep(DB::QueryPlan::Node*, std::list>&, std::unique_ptr>&) @ 0x000000001c4a7b13 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:582: DB::QueryPlanOptimizations::tryPushDownFilter(DB::QueryPlan::Node*, std::list>&, DB::QueryPlanOptimizations::Optimization::ExtraSettings const&) @ 0x000000001c4a4b7a 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:95: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47a012 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d902 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:17:46.371921 [ 1867 ] {} TCPHandler: Code: 10. DB::Exception: Not found column toUInt128(__table2.id): in block __table2.id UUID UUID(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:977: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d2fad 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 6. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000001c0b4ee0 7. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000001c321a81 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&&, bool&) @ 0x000000001895ff08 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:155: DB::QueryPlanOptimizations::addNewFilterStepOrThrow(DB::QueryPlan::Node*, std::list>&, DB::ActionsDAG, bool, unsigned long, bool) @ 0x000000001c4a94e2 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:399: DB::QueryPlanOptimizations::tryPushDownOverJoinStep(DB::QueryPlan::Node*, std::list>&, std::unique_ptr>&) @ 0x000000001c4a7b13 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:582: DB::QueryPlanOptimizations::tryPushDownFilter(DB::QueryPlan::Node*, std::list>&, DB::QueryPlanOptimizations::Optimization::ExtraSettings const&) @ 0x000000001c4a4b7a 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:95: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47a012 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d902 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:17:46.504330 [ 1867 ] {68615eb3-c1dc-4e40-b31f-ddb767658bb7} executeQuery: Code: 10. DB::Exception: Not found column toUInt128(__table2.id): in block __table2.id UUID UUID(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45804) (comment: 03393_join_bug_77848.sql) (query 9, line 16) (in query: SELECT equals(i.id_uint, 12) FROM BadTable i LEFT JOIN BadJoin c ON i.id_uint = toUInt128(c.id) WHERE equals(i.id_uint, 12);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:977: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d2fad 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 6. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000001c0b4ee0 7. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000001c321a81 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&&, bool&) @ 0x000000001895ff08 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:155: DB::QueryPlanOptimizations::addNewFilterStepOrThrow(DB::QueryPlan::Node*, std::list>&, DB::ActionsDAG, bool, unsigned long, bool) @ 0x000000001c4a94e2 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:399: DB::QueryPlanOptimizations::tryPushDownOverJoinStep(DB::QueryPlan::Node*, std::list>&, std::unique_ptr>&) @ 0x000000001c4a7b13 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:582: DB::QueryPlanOptimizations::tryPushDownFilter(DB::QueryPlan::Node*, std::list>&, DB::QueryPlanOptimizations::Optimization::ExtraSettings const&) @ 0x000000001c4a4b7a 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:95: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47a012 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d902 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:17:46.506619 [ 1867 ] {} TCPHandler: Code: 10. DB::Exception: Not found column toUInt128(__table2.id): in block __table2.id UUID UUID(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:977: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d2fad 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 6. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000001c0b4ee0 7. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000001c321a81 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&&, bool&) @ 0x000000001895ff08 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:155: DB::QueryPlanOptimizations::addNewFilterStepOrThrow(DB::QueryPlan::Node*, std::list>&, DB::ActionsDAG, bool, unsigned long, bool) @ 0x000000001c4a94e2 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:399: DB::QueryPlanOptimizations::tryPushDownOverJoinStep(DB::QueryPlan::Node*, std::list>&, std::unique_ptr>&) @ 0x000000001c4a7b13 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:582: DB::QueryPlanOptimizations::tryPushDownFilter(DB::QueryPlan::Node*, std::list>&, DB::QueryPlanOptimizations::Optimization::ExtraSettings const&) @ 0x000000001c4a4b7a 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:95: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47a012 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d902 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:17:47.670080 [ 1860 ] {5881c93a-98b8-41cd-8452-e9c365e40117} executeQuery: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.a :: 0, _CAST(2147483648_UInt32, 'UInt32'_String) :: 1) -> equals(__table1.a, _CAST(2147483648_UInt32, 'UInt32'_String)) UInt8 : 3'. (DECIMAL_OVERFLOW) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45852) (comment: 00700_decimal_compare.sql) (query 30, line 50) (in query: SELECT toUInt32(2147483648) AS x, a == x FROM decimal WHERE a = 42;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. char8_t DB::DecimalComparison, unsigned int, DB::EqualsOp>::apply(DB::Decimal, unsigned int, int) @ 0x000000000a8dfa2e 5. void DB::DecimalComparison, unsigned int, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned int, DB::PODArray, 63ul, 64ul>&, int) @ 0x000000000a8dfbb6 6. COW::immutable_ptr DB::DecimalComparison, unsigned int, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, int) @ 0x000000000a8deeca 7. DB::DecimalComparison, unsigned int, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a8dd746 8. bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000a669f16 9. COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a68a2f3 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a674cdc 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:17:47.672434 [ 1860 ] {} TCPHandler: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.a :: 0, _CAST(2147483648_UInt32, 'UInt32'_String) :: 1) -> equals(__table1.a, _CAST(2147483648_UInt32, 'UInt32'_String)) UInt8 : 3'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. char8_t DB::DecimalComparison, unsigned int, DB::EqualsOp>::apply(DB::Decimal, unsigned int, int) @ 0x000000000a8dfa2e 5. void DB::DecimalComparison, unsigned int, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned int, DB::PODArray, 63ul, 64ul>&, int) @ 0x000000000a8dfbb6 6. COW::immutable_ptr DB::DecimalComparison, unsigned int, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, int) @ 0x000000000a8deeca 7. DB::DecimalComparison, unsigned int, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a8dd746 8. bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000a669f16 9. COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a68a2f3 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a674cdc 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:47.826437 [ 1860 ] {832dfb6b-199d-4016-8e02-328accaa846d} executeQuery: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.b :: 0, _CAST(9223372036854775808_UInt64, 'UInt64'_String) :: 1) -> equals(__table1.b, _CAST(9223372036854775808_UInt64, 'UInt64'_String)) UInt8 : 3'. (DECIMAL_OVERFLOW) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45852) (comment: 00700_decimal_compare.sql) (query 32, line 52) (in query: SELECT toUInt64(9223372036854775808) AS x, b == x FROM decimal WHERE a = 42;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. char8_t DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::Decimal, unsigned long, long) @ 0x000000000a92ceb0 5. void DB::DecimalComparison, unsigned long, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, long) @ 0x000000000a92d037 6. COW::immutable_ptr DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, long) @ 0x000000000a92c6ab 7. DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a92b80c 8. bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000a66a5bf 9. COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a68a2f3 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a674cdc 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:17:47.828402 [ 1860 ] {} TCPHandler: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.b :: 0, _CAST(9223372036854775808_UInt64, 'UInt64'_String) :: 1) -> equals(__table1.b, _CAST(9223372036854775808_UInt64, 'UInt64'_String)) UInt8 : 3'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. char8_t DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::Decimal, unsigned long, long) @ 0x000000000a92ceb0 5. void DB::DecimalComparison, unsigned long, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, long) @ 0x000000000a92d037 6. COW::immutable_ptr DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, long) @ 0x000000000a92c6ab 7. DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a92b80c 8. bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000a66a5bf 9. COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a68a2f3 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a674cdc 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:48.025320 [ 1860 ] {302b8061-4bb9-4ef3-b396-02111437f581} executeQuery: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.g :: 0, 30000_UInt16 :: 1) -> equals(__table1.g, 30000_UInt16) UInt8 : 2'. (DECIMAL_OVERFLOW) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45852) (comment: 00700_decimal_compare.sql) (query 36, line 57) (in query: SELECT g = 30000 FROM decimal WHERE a = 42;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. char8_t DB::DecimalComparison, unsigned short, DB::EqualsOp>::apply(DB::Decimal, unsigned short, int) @ 0x000000000a8dafb7 5. void DB::DecimalComparison, unsigned short, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned short, DB::PODArray, 63ul, 64ul>&, int) @ 0x000000000a8db136 6. COW::immutable_ptr DB::DecimalComparison, unsigned short, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, int) @ 0x000000000a8d9f2c 7. DB::DecimalComparison, unsigned short, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a8d9102 8. bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000a66ae68 9. COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a68a2f3 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a674cdc 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:17:48.027019 [ 1860 ] {} TCPHandler: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.g :: 0, 30000_UInt16 :: 1) -> equals(__table1.g, 30000_UInt16) UInt8 : 2'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. char8_t DB::DecimalComparison, unsigned short, DB::EqualsOp>::apply(DB::Decimal, unsigned short, int) @ 0x000000000a8dafb7 5. void DB::DecimalComparison, unsigned short, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned short, DB::PODArray, 63ul, 64ul>&, int) @ 0x000000000a8db136 6. COW::immutable_ptr DB::DecimalComparison, unsigned short, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, int) @ 0x000000000a8d9f2c 7. DB::DecimalComparison, unsigned short, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a8d9102 8. bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000a66ae68 9. COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a68a2f3 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a674cdc 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:48.159841 [ 1860 ] {8deafefb-656d-4129-8880-a83a02d6f5ee} executeQuery: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(30000_UInt16 :: 1, __table1.g :: 0) -> equals(30000_UInt16, __table1.g) UInt8 : 2'. (DECIMAL_OVERFLOW) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45852) (comment: 00700_decimal_compare.sql) (query 37, line 58) (in query: SELECT 30000 = g FROM decimal WHERE a = 42;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. char8_t DB::DecimalComparison, DB::EqualsOp>::apply(unsigned short, DB::Decimal, int) @ 0x000000000aa20f57 5. void DB::DecimalComparison, DB::EqualsOp>::constantVector(unsigned short, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, int) @ 0x000000000aa21016 6. COW::immutable_ptr DB::DecimalComparison, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, int) @ 0x000000000aa20116 7. DB::DecimalComparison, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000aa1fc86 8. bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000a66df28 9. COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a68a2f3 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a674cdc 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:17:48.161552 [ 1860 ] {} TCPHandler: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(30000_UInt16 :: 1, __table1.g :: 0) -> equals(30000_UInt16, __table1.g) UInt8 : 2'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. char8_t DB::DecimalComparison, DB::EqualsOp>::apply(unsigned short, DB::Decimal, int) @ 0x000000000aa20f57 5. void DB::DecimalComparison, DB::EqualsOp>::constantVector(unsigned short, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, int) @ 0x000000000aa21016 6. COW::immutable_ptr DB::DecimalComparison, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, int) @ 0x000000000aa20116 7. DB::DecimalComparison, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000aa1fc86 8. bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000a66df28 9. COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a68a2f3 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a674cdc 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:48.367196 [ 1860 ] {08ea12ba-5211-489a-bca7-151e523d0512} executeQuery: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.h :: 0, 10000000000_UInt64 :: 1) -> equals(__table1.h, 10000000000_UInt64) UInt8 : 2'. (DECIMAL_OVERFLOW) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45852) (comment: 00700_decimal_compare.sql) (query 40, line 61) (in query: SELECT h = 10000000000 FROM decimal WHERE a = 42;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. char8_t DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::Decimal, unsigned long, long) @ 0x000000000a92cb66 5. void DB::DecimalComparison, unsigned long, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, long) @ 0x000000000a92ccf7 6. COW::immutable_ptr DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, long) @ 0x000000000a92be0b 7. DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a92b886 8. bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000a66a5bf 9. COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a68a2f3 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a674cdc 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:17:48.369431 [ 1860 ] {} TCPHandler: Code: 407. DB::Exception: Can't compare decimal number due to overflow: while executing 'FUNCTION equals(__table1.h :: 0, 10000000000_UInt64 :: 1) -> equals(__table1.h, 10000000000_UInt64) UInt8 : 2'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. char8_t DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::Decimal, unsigned long, long) @ 0x000000000a92cb66 5. void DB::DecimalComparison, unsigned long, DB::EqualsOp>::vectorConstant(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, unsigned long, DB::PODArray, 63ul, 64ul>&, long) @ 0x000000000a92ccf7 6. COW::immutable_ptr DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(COW::immutable_ptr const&, COW::immutable_ptr const&, long) @ 0x000000000a92be0b 7. DB::DecimalComparison, unsigned long, DB::EqualsOp>::apply(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a92b886 8. bool DB::callOnAtLeastOneDecimalType::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&>(DB::TypeIndex, DB::TypeIndex, COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool)::'lambda'(auto const&)&) @ 0x000000000a66a5bf 9. COW::immutable_ptr DB::executeDecimal(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, bool) @ 0x000000000a68a2f3 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a674cdc 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 16. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 17. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 18. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:17:48.614961 [ 1867 ] {f5f92396-a435-428a-acb6-969da76f6d75} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53852) (comment: 01942_snowflakeToDateTime.sql) (query 2, line 3) (in query: -- Error cases SELECT snowflakeToDateTime();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec496cf 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:48.616132 [ 1867 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec496cf 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:48.746184 [ 1867 ] {04b1366f-0e9b-4bb5-ba26-b5fe7e61ddd1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime64'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53852) (comment: 01942_snowflakeToDateTime.sql) (query 3, line 5) (in query: SELECT snowflakeToDateTime64();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec4a20f 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:48.747397 [ 1867 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime64'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000015f319cc 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f68b 5. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec4a20f 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:48.938407 [ 1867 ] {937dd02e-3cb2-4763-aee7-9a59b34b221c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime'. Expected: Int64, got: String: In scope SELECT snowflakeToDateTime('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53852) (comment: 01942_snowflakeToDateTime.sql) (query 4, line 7) (in query: SELECT snowflakeToDateTime('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec496cf 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:17:48.939745 [ 1867 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime'. Expected: Int64, got: String: In scope SELECT snowflakeToDateTime('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec496cf 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:17:48.975629 [ 1808 ] {} TCPHandler: Code: 702. DB::Exception: Client info's client_name does not match: ClickHouse client not equal to Hacker client. (CLIENT_INFO_DOES_NOT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000087ec0e6 4. ./build_docker/./src/Server/TCPHandler.cpp:220: DB::TCPHandler::processQuery(std::optional&) @ 0x000000001bbf12a2 5. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001bbe96b5 6. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000001bbd9ee7 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:17:49.066564 [ 1808 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 58. Bytes expected: 83. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ac8c7a6 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000010c2a88d 5. ./src/IO/ReadHelpers.h:149: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000010c55d32 6. ./build_docker/./src/Server/TCPHandler.cpp:1830: DB::TCPHandler::processUnexpectedHello() @ 0x000000001bbef469 7. ./build_docker/./src/Server/TCPHandler.cpp:892: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001bbe98b1 8. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000001bbd9ee7 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:17:49.069876 [ 2114 ] {} TCPHandler: Code: 702. DB::Exception: Client info's version does not match: 20.13.0 (54443) not equal to 16.13.1 (54443). (CLIENT_INFO_DOES_NOT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Server/TCPHandler.cpp:228: DB::TCPHandler::processQuery(std::optional&) @ 0x000000001bbf414b 5. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001bbe96b5 6. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000001bbd9ee7 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:17:49.070213 [ 2114 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 58. Bytes expected: 83. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ac8c7a6 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000010c2a88d 5. ./src/IO/ReadHelpers.h:149: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000010c55d32 6. ./build_docker/./src/Server/TCPHandler.cpp:1830: DB::TCPHandler::processUnexpectedHello() @ 0x000000001bbef469 7. ./build_docker/./src/Server/TCPHandler.cpp:892: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001bbe98b1 8. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000001bbd9ee7 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:17:49.102450 [ 1867 ] {54718122-ee79-4eaa-b70b-44e59ad6fe42} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime64'. Expected: Int64, got: String: In scope SELECT snowflakeToDateTime64('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53852) (comment: 01942_snowflakeToDateTime.sql) (query 5, line 8) (in query: SELECT snowflakeToDateTime64('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec4a20f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:17:49.106431 [ 1867 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime64'. Expected: Int64, got: String: In scope SELECT snowflakeToDateTime64('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec4a20f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:17:49.114739 [ 1867 ] {2801003b-68b3-4919-807e-dd57ed51f689} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime'. Expected: Int64, got: String: In scope SELECT snowflakeToDateTime('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53852) (comment: 01942_snowflakeToDateTime.sql) (query 6, line 10) (in query: SELECT snowflakeToDateTime('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec496cf 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:17:49.115812 [ 1867 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime'. Expected: Int64, got: String: In scope SELECT snowflakeToDateTime('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec496cf 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:17:49.123905 [ 1867 ] {e9b537c6-0149-4cbd-8e53-106a3e69b757} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime64'. Expected: Int64, got: String: In scope SELECT snowflakeToDateTime64('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53852) (comment: 01942_snowflakeToDateTime.sql) (query 7, line 11) (in query: SELECT snowflakeToDateTime64('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec4a20f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:17:49.125250 [ 1867 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime64'. Expected: Int64, got: String: In scope SELECT snowflakeToDateTime64('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ec4a20f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:17:49.268568 [ 1867 ] {01bfa87c-0fc8-4e51-80b3-42a99b7531c3} executeQuery: Code: 721. DB::Exception: Function snowflakeToDateTime is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to 'true': In scope SELECT snowflakeToDateTime(CAST('123', 'Int64')) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53852) (comment: 01942_snowflakeToDateTime.sql) (query 8, line 13) (in query: SELECT snowflakeToDateTime(123::Int64) SETTINGS allow_deprecated_snowflake_conversion_functions = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec494f3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:49.269781 [ 1867 ] {} TCPHandler: Code: 721. DB::Exception: Function snowflakeToDateTime is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to 'true': In scope SELECT snowflakeToDateTime(CAST('123', 'Int64')) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionSnowflakeToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec494f3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:49.403755 [ 1867 ] {67f79377-98da-4e72-b32e-f61d3b9804fc} executeQuery: Code: 721. DB::Exception: Function snowflakeToDateTime64 is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to true: In scope SELECT snowflakeToDateTime64(CAST('123', 'Int64')) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53852) (comment: 01942_snowflakeToDateTime.sql) (query 9, line 14) (in query: SELECT snowflakeToDateTime64(123::Int64) SETTINGS allow_deprecated_snowflake_conversion_functions = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec4a020 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:49.404934 [ 1867 ] {} TCPHandler: Code: 721. DB::Exception: Function snowflakeToDateTime64 is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to true: In scope SELECT snowflakeToDateTime64(CAST('123', 'Int64')) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionSnowflakeToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ec4a020 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:17:49.838541 [ 24367 ] {2992ac32-fdb2-4b11-b635-9bce23be7eca} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_2rr1iutr.constrained (0941a9d4-63ea-439e-8b6b-12425b5bf77b) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53898) (comment: 00998_constraints_all_tables.sql) (query 3, line 3) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:49.839784 [ 24367 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_2rr1iutr.constrained (0941a9d4-63ea-439e-8b6b-12425b5bf77b) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:49.850667 [ 24367 ] {9b72cc01-e53e-4af0-baf4-5c77f072df1b} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_2rr1iutr.constrained (0941a9d4-63ea-439e-8b6b-12425b5bf77b) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53898) (comment: 00998_constraints_all_tables.sql) (query 4, line 4) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:49.852313 [ 24367 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_2rr1iutr.constrained (0941a9d4-63ea-439e-8b6b-12425b5bf77b) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:49.913584 [ 24367 ] {2d7164c2-2ab3-44f3-89b8-f8c99d8210e9} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_2rr1iutr.constrained (966b97b2-2da9-4360-99df-f8d852262705) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53898) (comment: 00998_constraints_all_tables.sql) (query 8, line 9) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:49.916217 [ 24367 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_2rr1iutr.constrained (966b97b2-2da9-4360-99df-f8d852262705) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:49.957150 [ 24367 ] {1102cde4-591d-4dde-92c2-e99f8310f76c} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_2rr1iutr.constrained (966b97b2-2da9-4360-99df-f8d852262705) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53898) (comment: 00998_constraints_all_tables.sql) (query 10, line 11) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:49.958723 [ 24367 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_2rr1iutr.constrained (966b97b2-2da9-4360-99df-f8d852262705) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.069798 [ 24367 ] {b554f639-19c6-4e0c-aaa1-632f25ebd14c} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_2rr1iutr.constrained (0591c6dc-93eb-4e25-b678-e3da71ff38df) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53898) (comment: 00998_constraints_all_tables.sql) (query 16, line 18) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.073963 [ 24367 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_2rr1iutr.constrained (0591c6dc-93eb-4e25-b678-e3da71ff38df) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.106902 [ 24367 ] {a9273b49-ffe3-45c7-b302-da426f338c47} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_2rr1iutr.constrained (0591c6dc-93eb-4e25-b678-e3da71ff38df) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53898) (comment: 00998_constraints_all_tables.sql) (query 18, line 20) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.109280 [ 24367 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_2rr1iutr.constrained (0591c6dc-93eb-4e25-b678-e3da71ff38df) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.219375 [ 24367 ] {9bf6ac99-5d72-470f-9dd1-563927f03a45} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_2rr1iutr.constrained (36f9682f-814a-4a80-a834-d17c5b8af733) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53898) (comment: 00998_constraints_all_tables.sql) (query 24, line 27) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.221111 [ 24367 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_2rr1iutr.constrained (36f9682f-814a-4a80-a834-d17c5b8af733) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.353782 [ 24367 ] {19cf6f33-ff8f-4d18-bc08-d97f3036d19d} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_2rr1iutr.constrained (36f9682f-814a-4a80-a834-d17c5b8af733) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53898) (comment: 00998_constraints_all_tables.sql) (query 26, line 29) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.355758 [ 24367 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_2rr1iutr.constrained (36f9682f-814a-4a80-a834-d17c5b8af733) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.472465 [ 24367 ] {1bea34bc-4396-4600-ae21-13697e1bc947} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_2rr1iutr.constrained (388018ff-cb04-4000-a6f7-c1c356b90e0d) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53898) (comment: 00998_constraints_all_tables.sql) (query 32, line 36) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.474839 [ 24367 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_2rr1iutr.constrained (388018ff-cb04-4000-a6f7-c1c356b90e0d) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.514228 [ 24367 ] {51aa98ac-e528-4f6a-8842-1a8e441fe09d} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_2rr1iutr.constrained (388018ff-cb04-4000-a6f7-c1c356b90e0d) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53898) (comment: 00998_constraints_all_tables.sql) (query 34, line 38) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.516470 [ 24367 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_2rr1iutr.constrained (388018ff-cb04-4000-a6f7-c1c356b90e0d) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.647804 [ 1851 ] {a286a200-6d25-440e-8e50-b54ae895b876} executeQuery: Code: 36. DB::Exception: Columns: a listed both in columns to sum and in partition key. That is not allowed. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53914) (comment: 01373_summing_merge_tree_explicit_columns_definition.sql) (query 2, line 3) (in query: CREATE TABLE tt_error_1373 (`a` Int64, `d` Int64, `val` Int64) ENGINE = SummingMergeTree((a, val)) PARTITION BY a ORDER BY d SETTINGS index_granularity = 53288, min_bytes_for_wide_part = 17163338, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 119, min_bytes_for_full_part_storage = 532822310, compact_parts_max_bytes_to_buffer = 137731687, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 30540083, merge_max_block_size = 16008, old_parts_lifetime = 292., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7193563572, index_granularity_bytes = 21614468, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 71, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 80387, primary_key_compress_block_size = 82042, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1231: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x000000001b2e2d1a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:518: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e042b 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.649189 [ 1851 ] {} TCPHandler: Code: 36. DB::Exception: Columns: a listed both in columns to sum and in partition key. That is not allowed. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1231: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x000000001b2e2d1a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:518: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e042b 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.699225 [ 24367 ] {5cf7fd5d-6ea5-4819-829c-68666c3d9989} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_2rr1iutr.constrained (584a0c40-0f24-4beb-aaf1-430c82a678a1) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53898) (comment: 00998_constraints_all_tables.sql) (query 44, line 50) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.700773 [ 24367 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_2rr1iutr.constrained (584a0c40-0f24-4beb-aaf1-430c82a678a1) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.718155 [ 24367 ] {23259966-9b4c-4e10-aafc-4b9e0f76dbd5} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_2rr1iutr.constrained2 (32195a89-89c6-402c-bdea-d736977a906d) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53898) (comment: 00998_constraints_all_tables.sql) (query 45, line 51) (in query: INSERT INTO constrained2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:50.719514 [ 24367 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_2rr1iutr.constrained2 (32195a89-89c6-402c-bdea-d736977a906d) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:17:55.016476 [ 1808 ] {e5cacc92-7d8d-4cb0-ae55-3cafe46a6d1f} executeQuery: Code: 80. DB::Exception: Cannot CREATE a table AS test_n37n3cn5.mv_from_base_to_target, it is a Materialized View without storage. Use "AS test_n37n3cn5.target_table" instead. (INCORRECT_QUERY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54158) (comment: 03161_create_table_as_mv.sql) (query 12, line 14) (in query: CREATE TABLE other_table_2 AS mv_from_base_to_target;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1344: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000188bde2f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b6d1b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:17:55.017970 [ 1808 ] {} TCPHandler: Code: 80. DB::Exception: Cannot CREATE a table AS test_n37n3cn5.mv_from_base_to_target, it is a Materialized View without storage. Use "AS test_n37n3cn5.target_table" instead. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1344: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000188bde2f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b6d1b 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:17:56.641512 [ 1865 ] {dde0f987-ad6a-459d-a5bb-4c6fbf68a337} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e'). (UNKNOWN_SETTING) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54324) (comment: 03234_get_setting_or_default.sql) (query 9, line 11) (in query: SELECT getSetting('custom_e');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Core/BaseSettings.cpp:53: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x0000000016feddb9 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::get(std::basic_string_view>) const @ 0x00000000172b71ee 6. ./build_docker/./src/Core/Settings.cpp:6464: DB::Settings::get(std::basic_string_view>) const @ 0x000000001713689a 7. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000000ac98fd6 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac98e69 9. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:17:56.642701 [ 2054 ] {35c6fae2-679b-46cb-9a41-5db18a1f8e51} executeQuery: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types: While processing _CAST(a, 'Array(String)') AS a. (TYPE_MISMATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54314) (comment: 01732_alters_bad_conversions.sql) (query 5, line 6) (in query: ALTER TABLE bad_conversions MODIFY COLUMN a Array(String);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::detail::FunctionCast::createArrayWrapper(std::shared_ptr const&, DB::DataTypeArray const&) const @ 0x0000000015fe23b8 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fe1112 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fc7a8d 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5ed8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000179c7f86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000179c74ff 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000018357bbc 12. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000183688de 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000001835a076 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018358954 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001834bf4d 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001831d06c 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000183312c3 18. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:172: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x0000000018e385ac 19. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:184: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37e91 20. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3867: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b328220 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 22. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:56.642713 [ 1865 ] {} TCPHandler: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e'). (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Core/BaseSettings.cpp:53: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x0000000016feddb9 5. ./src/Core/BaseSettings.h:641: DB::BaseSettings::get(std::basic_string_view>) const @ 0x00000000172b71ee 6. ./build_docker/./src/Core/Settings.cpp:6464: DB::Settings::get(std::basic_string_view>) const @ 0x000000001713689a 7. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000000ac98fd6 8. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac98e69 9. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:17:56.643848 [ 2054 ] {} TCPHandler: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types: While processing _CAST(a, 'Array(String)') AS a. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::detail::FunctionCast::createArrayWrapper(std::shared_ptr const&, DB::DataTypeArray const&) const @ 0x0000000015fe23b8 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fe1112 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fc7a8d 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5ed8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000179c7f86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000179c74ff 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000018357bbc 12. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000183688de 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000001835a076 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018358954 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001834bf4d 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001831d06c 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000183312c3 18. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:172: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x0000000018e385ac 19. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:184: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37e91 20. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3867: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b328220 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 22. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:56.704625 [ 1865 ] {6c70d540-9991-4b9a-a1f4-53ffc2f88f85} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 1, should be 2: In scope SELECT getSettingOrDefault('custom_e'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54324) (comment: 03234_get_setting_or_default.sql) (query 14, line 18) (in query: SELECT getSettingOrDefault('custom_e');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:17:56.705805 [ 1865 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 1, should be 2: In scope SELECT getSettingOrDefault('custom_e'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:17:56.843223 [ 1865 ] {13b8797a-00a6-45b9-82bc-bbb6a0f6a4d2} executeQuery: Code: 43. DB::Exception: The argument of function getSettingOrDefault should be a constant string with the name of a setting: In scope SELECT getSettingOrDefault(115, 'name should be string'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54324) (comment: 03234_get_setting_or_default.sql) (query 15, line 19) (in query: SELECT getSettingOrDefault(115, 'name should be string');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)1>::getValue(std::vector> const&) const @ 0x000000000ac9a29e 5. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)1>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac99ea9 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:56.844461 [ 1865 ] {} TCPHandler: Code: 43. DB::Exception: The argument of function getSettingOrDefault should be a constant string with the name of a setting: In scope SELECT getSettingOrDefault(115, 'name should be string'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)1>::getValue(std::vector> const&) const @ 0x000000000ac9a29e 5. DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)1>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac99ea9 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:17:56.933917 [ 2054 ] {c16c4859-7b98-4f97-b444-84fa8da881e9} executeQuery: Code: 70. DB::Exception: Enum conversion changes value for element 'foo' from 1 to 2: While processing _CAST(e, 'Enum8(\'bar\' = 1, \'foo\' = 2)') AS e. (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54314) (comment: 01732_alters_bad_conversions.sql) (query 10, line 12) (in query: ALTER TABLE bad_conversions_2 MODIFY COLUMN e Enum('bar' = 1, 'foo' = 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001232722c 4. _ZNK2DB6detail12FunctionCast25checkEnumToEnumConversionINS_12DataTypeEnumIDB8_EES5_EEvPKT_PKT0_ @ 0x000000001618e159 5. std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createEnumWrapper<_BitInt(8)>(DB::ColumnNullable, DB::DataTypeEnum<_BitInt(8)> const*) const @ 0x000000001618daf4 6. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fdf798 7. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fc7a8d 8. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5ed8 9. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000179c7f86 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000179c74ff 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000018357bbc 13. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000183688de 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000001835a076 15. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018358954 16. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001834bf4d 17. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001831d06c 18. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000183312c3 19. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:172: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x0000000018e385ac 20. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:184: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37e91 21. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3867: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b328220 22. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 23. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:17:56.935466 [ 2054 ] {} TCPHandler: Code: 70. DB::Exception: Enum conversion changes value for element 'foo' from 1 to 2: While processing _CAST(e, 'Enum8(\'bar\' = 1, \'foo\' = 2)') AS e. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001232722c 4. _ZNK2DB6detail12FunctionCast25checkEnumToEnumConversionINS_12DataTypeEnumIDB8_EES5_EEvPKT_PKT0_ @ 0x000000001618e159 5. std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createEnumWrapper<_BitInt(8)>(DB::ColumnNullable, DB::DataTypeEnum<_BitInt(8)> const*) const @ 0x000000001618daf4 6. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fdf798 7. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fc7a8d 8. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5ed8 9. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000179c7f86 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000179c74ff 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000018357bbc 13. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000183688de 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000001835a076 15. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018358954 16. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001834bf4d 17. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001831d06c 18. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000183312c3 19. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:172: DB::(anonymous namespace)::createExpressions(DB::Block const&, std::shared_ptr, bool, std::shared_ptr) @ 0x0000000018e385ac 20. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:184: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37e91 21. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3867: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b328220 22. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 23. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:17:57.393693 [ 16822 ] {d0f44859-7e12-4bf9-9e46-a215512d6d72} executeQuery: Code: 44. DB::Exception: Function 'like' doesn't support search with non-constant needles in constant haystack. (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54340) (comment: 03278_enum_string_functions.sql) (query 33, line 41) (in query: SELECT CAST('a', 'Enum(\'a\' = 1)') LIKE randomString(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000881a760 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000caad038 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 15. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 16. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:17:57.394799 [ 16822 ] {} TCPHandler: Code: 44. DB::Exception: Function 'like' doesn't support search with non-constant needles in constant haystack. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000881a760 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000caad038 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 15. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 16. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:17:57.420602 [ 16822 ] {da8ef838-88a1-4330-9841-9abd8c32932e} executeQuery: Code: 44. DB::Exception: Function 'like' doesn't support search with non-constant needles in constant haystack. (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54340) (comment: 03278_enum_string_functions.sql) (query 35, line 44) (in query: SELECT CAST('a', 'Enum16(\'a\' = 1)') LIKE randomString(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000881a760 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000caad038 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 15. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 16. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:17:57.421541 [ 16822 ] {} TCPHandler: Code: 44. DB::Exception: Function 'like' doesn't support search with non-constant needles in constant haystack. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000881a760 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000caad038 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 15. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 16. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:17:57.638126 [ 24367 ] {14852f66-4fc7-4372-9451-77c70463fe62} executeQuery: Code: 36. DB::Exception: Only `Float64` data type is allowed for the value column of GraphiteMergeTree. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54890) (comment: 02508_bad_graphite.sql) (query 3, line 5) (in query: INSERT INTO test_graphite (key) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/Merges/Algorithms/GraphiteRollupSortedAlgorithm.cpp:36: DB::GraphiteRollupSortedAlgorithm::GraphiteRollupSortedAlgorithm(DB::Block const&, unsigned long, DB::SortDescription, unsigned long, unsigned long, DB::Graphite::Params, long) @ 0x000000001c21cee1 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::GraphiteRollupSortedAlgorithm* std::construct_at[abi:ne190107](DB::GraphiteRollupSortedAlgorithm*, DB::Block&, int&&, DB::SortDescription&, unsigned long&&, int&&, DB::Graphite::Params const&, long&&) @ 0x000000001b475ade 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x000000001b467735 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:613: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000001b46a3da 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001b468732 9. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000001b80120c 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 18. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 19. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:17:57.639901 [ 24367 ] {} TCPHandler: Code: 36. DB::Exception: Only `Float64` data type is allowed for the value column of GraphiteMergeTree. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/Merges/Algorithms/GraphiteRollupSortedAlgorithm.cpp:36: DB::GraphiteRollupSortedAlgorithm::GraphiteRollupSortedAlgorithm(DB::Block const&, unsigned long, DB::SortDescription, unsigned long, unsigned long, DB::Graphite::Params, long) @ 0x000000001c21cee1 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::GraphiteRollupSortedAlgorithm* std::construct_at[abi:ne190107](DB::GraphiteRollupSortedAlgorithm*, DB::Block&, int&&, DB::SortDescription&, unsigned long&&, int&&, DB::Graphite::Params const&, long&&) @ 0x000000001b475ade 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x000000001b467735 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:613: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000001b46a3da 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001b468732 9. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000001b80120c 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001c1f75ed 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 18. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 19. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:17:57.908487 [ 2095 ] {803ea242-0bb1-41c9-bf08-2b8d070ce76f} executeQuery: Code: 252. DB::Exception: Too many inactive parts (2) in table 'test_r39n0qvs.data_01709 (f3245079-fa3a-40bb-a6d1-e569f8d5a447)'. Parts cleaning are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54920) (comment: 01709_inactive_parts_to_throw_insert.sql) (query 6, line 10) (in query: insert into data_01709 values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ac8c7a6 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4913: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001b3481bc 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000001b7ffc7b 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0471 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afad9 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x000000001bd2b0a2 13. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbea796 14. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:17:57.909756 [ 2095 ] {} TCPHandler: Code: 252. DB::Exception: Too many inactive parts (2) in table 'test_r39n0qvs.data_01709 (f3245079-fa3a-40bb-a6d1-e569f8d5a447)'. Parts cleaning are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ac8c7a6 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4913: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001b3481bc 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000001b7ffc7b 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0471 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afad9 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x000000001bd2b0a2 13. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbea796 14. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:18:01.796121 [ 1851 ] {bc9654f6-a93d-41b2-89d8-f281dc7642f5} executeQuery: Code: 691. DB::Exception: Unknown element 'xyz' for enum: while converting 'xyz' to Enum8('hello' = 1, 'world' = 2). (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55132) (comment: 01310_enum_comparison.sql) (query 7, line 9) (in query: SELECT count() FROM enum WHERE x = 'xyz';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x00000000174b3659 5. ./build_docker/./src/DataTypes/Serializations/SerializationEnum.cpp:99: DB::SerializationEnum<_BitInt(8)>::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001755b5a5 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd6adf 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 8. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6897d0 9. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6740a5 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 16. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000001c0b4ee0 18. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000001c321a81 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000001895e815 20. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898e9cd 21. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x00000000189866e7 22. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:18:01.797928 [ 1851 ] {} TCPHandler: Code: 691. DB::Exception: Unknown element 'xyz' for enum: while converting 'xyz' to Enum8('hello' = 1, 'world' = 2). (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x00000000174b3659 5. ./build_docker/./src/DataTypes/Serializations/SerializationEnum.cpp:99: DB::SerializationEnum<_BitInt(8)>::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000001755b5a5 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd6adf 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 8. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6897d0 9. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6740a5 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 16. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 17. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000001c0b4ee0 18. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000001c321a81 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x000000001895e815 20. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898e9cd 21. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x00000000189866e7 22. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:18:01.980834 [ 2054 ] {dfc701f1-e91a-4027-a36d-eb3a5ea73c16} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalDay and IntervalMonth because the number of days in a month is not fixed: In scope SELECT toIntervalDay(30) < toIntervalMonth(1). (NO_COMMON_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55150) (comment: 02906_interval_comparison.sql) (query 2, line 3) (in query: -- It is reasonable to not give an answer for this: SELECT INTERVAL 30 DAY < INTERVAL 1 MONTH;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x00000000174fc952 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000174ffb2f 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000c3c5a22 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c3b0180 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:18:01.982320 [ 2054 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalDay and IntervalMonth because the number of days in a month is not fixed: In scope SELECT toIntervalDay(30) < toIntervalMonth(1). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x00000000174fc952 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000174ffb2f 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000c3c5a22 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c3b0180 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:18:02.118432 [ 2054 ] {6406894f-1824-4d53-ab78-74258c90e290} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalSecond and IntervalYear because the number of days in a month is not fixed: In scope SELECT toIntervalSecond(1) = toIntervalYear(1). (NO_COMMON_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55150) (comment: 02906_interval_comparison.sql) (query 3, line 5) (in query: -- This we could change in the future: SELECT INTERVAL 1 SECOND = INTERVAL 1 YEAR;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x00000000174fc952 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000174ffb2f 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000a68a8c2 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a674d20 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:18:02.119499 [ 2054 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalSecond and IntervalYear because the number of days in a month is not fixed: In scope SELECT toIntervalSecond(1) = toIntervalYear(1). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x00000000174fc952 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000174ffb2f 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000a68a8c2 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a674d20 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:18:02.241656 [ 2054 ] {fa0ba920-ceb7-4a42-8782-9fda548ac8bb} executeQuery: Code: 386. DB::Exception: Cannot compare intervals IntervalSecond and IntervalYear because the number of days in a month is not fixed: In scope SELECT toIntervalSecond(1) <= toIntervalYear(1). (NO_COMMON_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55150) (comment: 02906_interval_comparison.sql) (query 4, line 7) (in query: SELECT INTERVAL 1 SECOND <= INTERVAL 1 YEAR;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x00000000174fc952 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000174ffb2f 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000c746f22 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c731680 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:18:02.242946 [ 2054 ] {} TCPHandler: Code: 386. DB::Exception: Cannot compare intervals IntervalSecond and IntervalYear because the number of days in a month is not fixed: In scope SELECT toIntervalSecond(1) <= toIntervalYear(1). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:261: DB::(anonymous namespace)::findSmallestIntervalSuperType(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>&) @ 0x00000000174fc952 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:695: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000174ffb2f 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000c746f22 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c731680 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:18:02.783950 [ 16822 ] {c40d428d-bd5c-4353-8059-6d51a00324cc} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55204) (comment: 01178_int_field_to_decimal.sql) (query 1, line 1) (in query: select d from values('d Decimal(8, 8)', 0, 1) where d not in (-1, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000018ddcab1 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd61af 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd7e5a 8. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cc86bc 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:18:02.785211 [ 16822 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000018ddcab1 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd61af 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd7e5a 8. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cc86bc 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:18:02.794524 [ 16822 ] {c3c03e17-c94a-4312-b6b8-9e540d482937} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55204) (comment: 01178_int_field_to_decimal.sql) (query 2, line 2) (in query: select d from values('d Decimal(8, 8)', 0, 2) where d not in (1, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000018ddcab1 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd61af 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd7e5a 8. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cc86bc 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:18:02.795564 [ 16822 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000018ddcab1 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd61af 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd7e5a 8. ./build_docker/./src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cc86bc 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:18:02.909696 [ 16822 ] {e949531d-3373-444b-9779-4d99a5c59ec7} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55204) (comment: 01178_int_field_to_decimal.sql) (query 3, line 3) (in query: select d from values('d Decimal(9, 8)', 0, 3) where d not in (-9223372036854775808, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000018ddcbb7 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd61af 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000018dd8204 8. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000017f10008 9. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000017f0da99 10. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000017f1cdff 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x0000000017f1c871 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x0000000017f1c7b6 13. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982c4c 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:18:02.911161 [ 16822 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000018ddcbb7 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd61af 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000018dd8204 8. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000017f10008 9. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000017f0da99 10. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000017f1cdff 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x0000000017f1c871 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x0000000017f1c7b6 13. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982c4c 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.016460 [ 16822 ] {9350b6dc-0adc-4be4-92db-c84c938ea573} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55204) (comment: 01178_int_field_to_decimal.sql) (query 4, line 4) (in query: select d from values('d Decimal(9, 8)', 0, 4) where d not in (18446744073709551615, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000018ddcab1 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd61af 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000018dd8204 8. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000017f10008 9. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000017f0da99 10. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000017f1cdff 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x0000000017f1c871 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x0000000017f1c7b6 13. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982c4c 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.017968 [ 16822 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000018ddcab1 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd61af 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000018dd8204 8. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000017f10008 9. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000017f0da99 10. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000017f1cdff 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x0000000017f1c871 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x0000000017f1c7b6 13. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982c4c 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.127210 [ 16822 ] {db58265b-6ca4-4be8-82a4-be541bcff44d} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55204) (comment: 01178_int_field_to_decimal.sql) (query 5, line 5) (in query: select d from values('d Decimal(18, 8)', 0, 5) where d not in (-9223372036854775808, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000018ddd5d8 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:255: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd63f5 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000018dd8204 8. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000017f10008 9. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000017f0da99 10. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000017f1cdff 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x0000000017f1c871 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x0000000017f1c7b6 13. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982c4c 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.128793 [ 16822 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000018ddd5d8 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:255: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd63f5 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000018dd8204 8. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000017f10008 9. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000017f0da99 10. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000017f1cdff 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x0000000017f1c871 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x0000000017f1c7b6 13. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982c4c 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.238636 [ 16822 ] {7f123f8d-16e5-4702-a088-818651207eca} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55204) (comment: 01178_int_field_to_decimal.sql) (query 6, line 6) (in query: select d from values('d Decimal(18, 8)', 0, 6) where d not in (18446744073709551615, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000018ddd4d2 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:255: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd63f5 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000018dd8204 8. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000017f10008 9. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000017f0da99 10. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000017f1cdff 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x0000000017f1c871 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x0000000017f1c7b6 13. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982c4c 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.239912 [ 16822 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000018ddd4d2 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:255: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd63f5 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000018dd8204 8. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000017f10008 9. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000017f0da99 10. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000017f1cdff 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x0000000017f1c871 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x0000000017f1c7b6 13. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982c4c 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.334502 [ 16822 ] {3b6b824b-f987-4307-9f8d-3257ab5674b9} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(26, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55204) (comment: 01178_int_field_to_decimal.sql) (query 7, line 7) (in query: select d from values('d Decimal(26, 8)', 0, 7) where d not in (-9223372036854775808, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x0000000018dddfc2 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:257: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd6896 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000018dd8204 8. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000017f10008 9. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000017f0da99 10. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000017f1cdff 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x0000000017f1c871 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x0000000017f1c7b6 13. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982c4c 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.337825 [ 16822 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(26, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x0000000018dddfc2 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:257: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd6896 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000018dd8204 8. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000017f10008 9. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000017f0da99 10. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000017f1cdff 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x0000000017f1c871 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x0000000017f1c7b6 13. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982c4c 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.463129 [ 16822 ] {eaf58966-0da8-4c3a-a665-2502fe53a925} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(27, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55204) (comment: 01178_int_field_to_decimal.sql) (query 8, line 8) (in query: select d from values('d Decimal(27, 8)', 0, 8) where d not in (18446744073709551615, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x0000000018dde045 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:257: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd6896 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000018dd8204 8. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000017f10008 9. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000017f0da99 10. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000017f1cdff 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x0000000017f1c871 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x0000000017f1c7b6 13. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982c4c 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.464492 [ 16822 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(27, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x0000000018dde045 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:257: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd6896 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000018dd44ab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000018dd8204 8. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000017f10008 9. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000017f0da99 10. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x0000000017f1cdff 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x0000000017f1c871 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x0000000017f1c7b6 13. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000018982c4c 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.743941 [ 24367 ] {1f4e6dd3-4d0e-41bc-b450-e982b2753faa} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 14, line 17) (in query: SELECT t1.*, t2.* from t1 LEFT JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b8857 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.745313 [ 24367 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b8857 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.839149 [ 24379 ] {c8676d09-19eb-49b3-8f3b-b23fcd38aefe} executeQuery: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55262) (comment: 01883_with_grouping_sets.sql) (query 10, line 36) (in query: SELECT fact_1_id, fact_3_id, SUM(sales_value) AS sales_value FROM grouping_sets GROUP BY grouping sets ((fact_1_id), (fact_1_id, fact_3_id)) WITH TOTALS ORDER BY fact_1_id, fact_3_id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8170a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.840376 [ 24379 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8170a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.862205 [ 24379 ] {d4580635-525b-4493-a87f-0efe308b65db} executeQuery: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55262) (comment: 01883_with_grouping_sets.sql) (query 12, line 52) (in query: SELECT fact_1_id, fact_3_id, SUM(sales_value) AS sales_value FROM grouping_sets GROUP BY grouping sets (fact_1_id, (fact_1_id, fact_3_id)) WITH TOTALS ORDER BY fact_1_id, fact_3_id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8170a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:18:03.863282 [ 24379 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8170a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:18:04.138850 [ 24367 ] {fe29c09f-eb3e-4c62-a257-56a91248f244} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 21, line 24) (in query: SELECT t1.*, t2.* from t1 INNER JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b8857 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:18:04.140637 [ 24367 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b8857 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:18:04.601083 [ 24367 ] {1ba5c621-eef2-47c5-95fe-5f4cfe6dcd90} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 28, line 31) (in query: SELECT t1.*, t2.* from t1 RIGHT JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b8857 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:18:04.602452 [ 24367 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b8857 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:18:04.978806 [ 24367 ] {54cb5af8-a782-4cd0-95d4-e49515f8771c} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 35, line 38) (in query: SELECT t1.*, t2.* from t1 FULL JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b8857 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:18:04.979909 [ 24367 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b8857 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:18:05.661507 [ 24367 ] {c137f6bd-4b95-48ba-9ceb-f45fd215f9d1} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 43, line 46) (in query: SELECT t1.*, t2.* from t1 LEFT JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000018878b9f 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b881e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 16. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:18:05.662794 [ 24367 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000018878b9f 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b881e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 16. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:18:06.088874 [ 24367 ] {35af3d64-4933-4bb7-b2b5-6a673f4fd755} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 50, line 53) (in query: SELECT t1.*, t2.* from t1 INNER JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000018878b9f 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b881e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 16. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:18:06.090003 [ 24367 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000018878b9f 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b881e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 16. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:18:06.477242 [ 24367 ] {efa8707a-35a6-4874-bbb3-c51296f13629} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 57, line 60) (in query: SELECT t1.*, t2.* from t1 RIGHT JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000018878b9f 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b881e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 16. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:18:06.478545 [ 24367 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000018878b9f 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b881e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 16. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:18:06.878938 [ 24367 ] {588b7b31-1226-47de-96e3-71bcd4bb40bd} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 64, line 67) (in query: SELECT t1.*, t2.* from t1 FULL JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000018878b9f 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b881e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 16. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:18:06.880170 [ 24367 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000018a42af7 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000018a42846 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000018f813d5 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000018878b9f 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000001c0b881e 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000001c339d3b 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000001c326229 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000001c336da6 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool, bool>(DB::Block const&, DB::Block const&, std::shared_ptr&, DB::SettingFieldNumber const&, DB::SettingFieldNumber const&, DB::SettingFieldMaxThreads const&, std::unordered_set, std::equal_to, std::allocator>&, bool&&, bool&&) @ 0x00000000189cff66 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1532: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b8073 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 15. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 16. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:18:09.717900 [ 24374 ] {bcd64299-3fb9-4c4d-a8fd-7e8761116369} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt64 of arguments of function least: In scope SELECT LEAST(-1., 18446744073709551615). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60052) (comment: 01246_least_greatest_generic.sql) (query 15, line 19) (in query: -- This can be improved SELECT LEAST(-1., 18446744073709551615);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c363773 5. DB::FunctionBinaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c121c16 6. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)0, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c120e97 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000090496a4 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:18:09.719545 [ 24374 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt64 of arguments of function least: In scope SELECT LEAST(-1., 18446744073709551615). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000088b972c 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c363773 5. DB::FunctionBinaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c121c16 6. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)0, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c120e97 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000090496a4 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:18:10.206480 [ 24374 ] {71775da6-2878-4ed7-9ac9-b1f11561d797} executeQuery: Code: 42. DB::Exception: Function greatest cannot be called without arguments: In scope SELECT Greatest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60052) (comment: 01246_least_greatest_generic.sql) (query 25, line 36) (in query: SELECT Greatest();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)1, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b6d7634 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000090496a4 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:18:10.207937 [ 24374 ] {} TCPHandler: Code: 42. DB::Exception: Function greatest cannot be called without arguments: In scope SELECT Greatest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)1, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b6d7634 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x00000000090496a4 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:18:11.346200 [ 24367 ] {5ca6ab3c-3e8a-4891-a073-7afdb5c87538} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 148, line 154) (in query: SELECT t1.*, t2.* FROM t1 LEFT JOIN t2 ON (t1.a < t2.a OR lower(t1.attr) == lower(t2.attr)) AND t1.key = t2.key ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.347990 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.374051 [ 24367 ] {79fe909f-341b-464c-96b6-10edc9deea86} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 149, line 155) (in query: SELECT t1.*, t2.* from t1 LEFT JOIN t2 ON t1.key = t2.key and (t1.b + t2.b == t1.c + t2.c) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.375132 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.397087 [ 24367 ] {753fc6f1-dd6a-463a-ae36-d055f48cec31} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 150, line 156) (in query: SELECT t1.*, t2.* from t1 LEFT JOIN t2 ON t1.key = t2.key and (t1.a < t2.a) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.397986 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.435449 [ 24367 ] {659c8507-538b-48df-a3c3-5f7bcb87aa14} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 151, line 157) (in query: SELECT t1.*, t2.* FROM t1 RIGHT JOIN t2 ON (t1.a < t2.a OR lower(t1.attr) == lower(t2.attr)) AND t1.key = t2.key ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.437379 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.461008 [ 24367 ] {89d4b60e-d9c2-497f-a5ed-e56e5180f0d7} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 152, line 158) (in query: SELECT t1.*, t2.* from t1 RIGHT JOIN t2 ON t1.key = t2.key and (t1.b + t2.b == t1.c + t2.c) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.462000 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.482016 [ 24367 ] {8d18a26f-fab4-4e4e-9020-ab822290477d} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 153, line 159) (in query: SELECT t1.*, t2.* from t1 RIGHT JOIN t2 ON t1.key = t2.key and (t1.a < t2.a) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.482918 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.504151 [ 24367 ] {7223e0e7-75c0-4024-a4b6-431953f0aacb} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 154, line 160) (in query: SELECT t1.*, t2.* FROM t1 FULL JOIN t2 ON (t1.a < t2.a OR lower(t1.attr) == lower(t2.attr)) AND t1.key = t2.key ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.505095 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.525308 [ 24367 ] {92a25772-fbe7-4f9a-9294-87ccd1154902} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 155, line 161) (in query: SELECT t1.*, t2.* from t1 FULL JOIN t2 ON t1.key = t2.key and (t1.b + t2.b == t1.c + t2.c) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.526209 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.548093 [ 24367 ] {75bdb5f4-45d4-49e8-9fb6-7ba2eced4229} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 156, line 162) (in query: SELECT t1.*, t2.* from t1 FULL JOIN t2 ON t1.key = t2.key and (t1.a < t2.a) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.549083 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.579385 [ 24367 ] {5d441ed0-2fa3-4e70-a6b7-e2c79c6371ed} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 158, line 164) (in query: SELECT t1.*, t2.* FROM t1 LEFT JOIN t2 ON (t1.a < t2.a OR lower(t1.attr) == lower(t2.attr)) AND t1.key = t2.key ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.580415 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.603544 [ 24367 ] {07474058-18f8-45c4-9567-4e9332287382} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 159, line 165) (in query: SELECT t1.*, t2.* from t1 LEFT JOIN t2 ON t1.key = t2.key and (t1.b + t2.b == t1.c + t2.c) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.604557 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.628822 [ 24367 ] {600d4034-a25a-4cd6-9719-3adc288f0a35} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 160, line 166) (in query: SELECT t1.*, t2.* from t1 LEFT JOIN t2 ON t1.key = t2.key and (t1.a < t2.a) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.629852 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.662151 [ 24367 ] {6c21e1bc-c7fa-44aa-a185-53b6556019f2} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 161, line 167) (in query: SELECT t1.*, t2.* FROM t1 RIGHT JOIN t2 ON (t1.a < t2.a OR lower(t1.attr) == lower(t2.attr)) AND t1.key = t2.key ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.663831 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.695168 [ 24367 ] {1c6a93cb-b1fd-4a00-912b-67efbbc1b257} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 162, line 168) (in query: SELECT t1.*, t2.* from t1 RIGHT JOIN t2 ON t1.key = t2.key and (t1.b + t2.b == t1.c + t2.c) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.696839 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.724618 [ 24367 ] {6b748a6b-9d13-47f5-b53a-2b2245155672} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 163, line 169) (in query: SELECT t1.*, t2.* from t1 RIGHT JOIN t2 ON t1.key = t2.key and (t1.a < t2.a) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.725783 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.756757 [ 24367 ] {da3b2bdb-3a09-49ca-8536-5d6029f8f473} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 164, line 170) (in query: SELECT t1.*, t2.* FROM t1 FULL JOIN t2 ON (t1.a < t2.a OR lower(t1.attr) == lower(t2.attr)) AND t1.key = t2.key ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.758140 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.792385 [ 24367 ] {419b0a06-d5bc-41f0-8475-e55bbed8e43f} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 165, line 171) (in query: SELECT t1.*, t2.* from t1 FULL JOIN t2 ON t1.key = t2.key and (t1.b + t2.b == t1.c + t2.c) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.794119 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.820275 [ 24367 ] {a9ae5fcf-94a8-4912-be47-8b324cacd5e4} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 166, line 172) (in query: SELECT t1.*, t2.* from t1 FULL JOIN t2 ON t1.key = t2.key and (t1.a < t2.a) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.821262 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.963177 [ 24367 ] {00bb2b7f-c866-42b2-8c9b-87150cd78d3a} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 168, line 174) (in query: SELECT t1.*, t2.* FROM t1 LEFT JOIN t2 ON (t1.a < t2.a OR lower(t1.attr) == lower(t2.attr)) AND t1.key = t2.key ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:11.968406 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.003806 [ 24367 ] {36dd0955-7b33-4ff2-8cba-e46c45f68911} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 169, line 175) (in query: SELECT t1.*, t2.* from t1 LEFT JOIN t2 ON t1.key = t2.key and (t1.b + t2.b == t1.c + t2.c) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.004887 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.051913 [ 24367 ] {53c4442f-a62e-4b82-a962-ceea6e34d95a} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 170, line 176) (in query: SELECT t1.*, t2.* from t1 LEFT JOIN t2 ON t1.key = t2.key and (t1.a < t2.a) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.054728 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.108707 [ 24367 ] {e9442337-639a-48e3-adee-69875e66c83a} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 171, line 177) (in query: SELECT t1.*, t2.* FROM t1 RIGHT JOIN t2 ON (t1.a < t2.a OR lower(t1.attr) == lower(t2.attr)) AND t1.key = t2.key ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.110618 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.143911 [ 24367 ] {c407a415-43b3-4f9c-a9d3-1d700a59906b} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 172, line 178) (in query: SELECT t1.*, t2.* from t1 RIGHT JOIN t2 ON t1.key = t2.key and (t1.b + t2.b == t1.c + t2.c) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.145472 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.187778 [ 24367 ] {08273b4c-5221-41ae-9ecd-07bf909f4ba1} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 173, line 179) (in query: SELECT t1.*, t2.* from t1 RIGHT JOIN t2 ON t1.key = t2.key and (t1.a < t2.a) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.189702 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.238306 [ 24367 ] {c52e1b35-9b33-4bb2-94db-cc9f5b1a57d7} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 174, line 180) (in query: SELECT t1.*, t2.* FROM t1 FULL JOIN t2 ON (t1.a < t2.a OR lower(t1.attr) == lower(t2.attr)) AND t1.key = t2.key ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.240891 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.274205 [ 24367 ] {5122044b-7bfb-496b-9f6f-d0c9b9a9058f} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 175, line 181) (in query: SELECT t1.*, t2.* from t1 FULL JOIN t2 ON t1.key = t2.key and (t1.b + t2.b == t1.c + t2.c) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.276163 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.306807 [ 24367 ] {68db2965-5c8c-48a7-9a41-04bbd5c3dddb} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 176, line 182) (in query: SELECT t1.*, t2.* from t1 FULL JOIN t2 ON t1.key = t2.key and (t1.a < t2.a) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.308390 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.350275 [ 24367 ] {376302cb-21d2-45ad-bb91-807ba7a98963} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 178, line 184) (in query: SELECT t1.*, t2.* FROM t1 LEFT JOIN t2 ON (t1.a < t2.a OR lower(t1.attr) == lower(t2.attr)) AND t1.key = t2.key ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.352145 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.380328 [ 24367 ] {8f6c6b6c-1b6b-432f-a4ca-3bc041e6acfa} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 179, line 185) (in query: SELECT t1.*, t2.* from t1 LEFT JOIN t2 ON t1.key = t2.key and (t1.b + t2.b == t1.c + t2.c) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.381391 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.403538 [ 24367 ] {5429d4e2-a827-4be2-a0ec-5b7bab3d89cf} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 180, line 186) (in query: SELECT t1.*, t2.* from t1 LEFT JOIN t2 ON t1.key = t2.key and (t1.a < t2.a) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.404410 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.433869 [ 24367 ] {7d4fba24-9086-4b05-b7f3-dfdf5878ce1f} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 181, line 187) (in query: SELECT t1.*, t2.* FROM t1 RIGHT JOIN t2 ON (t1.a < t2.a OR lower(t1.attr) == lower(t2.attr)) AND t1.key = t2.key ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.434999 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.470401 [ 24367 ] {be25326a-2ff4-4c57-9390-a45e45270b8e} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 182, line 188) (in query: SELECT t1.*, t2.* from t1 RIGHT JOIN t2 ON t1.key = t2.key and (t1.b + t2.b == t1.c + t2.c) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.472006 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.501184 [ 24367 ] {d99044c3-9d53-4327-b2df-b412ef7ddc2e} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 183, line 189) (in query: SELECT t1.*, t2.* from t1 RIGHT JOIN t2 ON t1.key = t2.key and (t1.a < t2.a) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.502525 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.535568 [ 24367 ] {b253a51f-6d07-435c-8900-2c3830ca3bcf} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 184, line 190) (in query: SELECT t1.*, t2.* FROM t1 FULL JOIN t2 ON (t1.a < t2.a OR lower(t1.attr) == lower(t2.attr)) AND t1.key = t2.key ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.537400 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.567326 [ 24367 ] {2fab3b1f-6c0a-4647-8351-4d6feac96ab8} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 185, line 191) (in query: SELECT t1.*, t2.* from t1 FULL JOIN t2 ON t1.key = t2.key and (t1.b + t2.b == t1.c + t2.c) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.568813 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.592094 [ 24367 ] {2aa02fda-e96a-4b9a-a75e-3594ebb6e562} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 186, line 192) (in query: SELECT t1.*, t2.* from t1 FULL JOIN t2 ON t1.key = t2.key and (t1.a < t2.a) ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.593401 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.944794 [ 24367 ] {d37bed7a-7b64-40cb-b549-94b09887f4b4} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 188, line 194) (in query: SELECT t1.*, t2.* FROM t1 LEFT JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189dea4d 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.947033 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189dea4d 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.973773 [ 24367 ] {2cc5daf4-3c61-46ac-89a1-1bbf72ce991c} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 189, line 195) (in query: SELECT t1.*, t2.* FROM t1 RIGHT JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189dea4d 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:12.975264 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189dea4d 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.000742 [ 24367 ] {1edd267c-8f84-46ad-9ec4-5e81fbc00385} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 190, line 196) (in query: SELECT t1.*, t2.* FROM t1 FULL JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189dea4d 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.001822 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189dea4d 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.041469 [ 24367 ] {4cf7e0df-57c6-4558-b1b3-fdf01ad7a8b9} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 192, line 198) (in query: SELECT t1.*, t2.* FROM t1 LEFT JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.042713 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.071434 [ 24367 ] {a51980b3-d0a3-4109-8c84-c50531d17eae} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 193, line 199) (in query: SELECT t1.*, t2.* FROM t1 RIGHT JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.072619 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.097168 [ 24367 ] {9a623abd-74b0-4ea0-a1f6-120b6188e55e} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 194, line 200) (in query: SELECT t1.*, t2.* FROM t1 FULL JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.098264 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.132417 [ 24367 ] {eadfde57-dd11-4cb1-b1db-6d97f4fb135e} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 196, line 202) (in query: SELECT t1.*, t2.* FROM t1 LEFT JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.133564 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.165907 [ 24367 ] {09e1235d-ff53-4d85-aad7-81bb349deb4e} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 197, line 203) (in query: SELECT t1.*, t2.* FROM t1 RIGHT JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.167246 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.190907 [ 24367 ] {bb9e3882-6d06-47aa-90a0-f5fd56e322c9} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 198, line 204) (in query: SELECT t1.*, t2.* FROM t1 FULL JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.193420 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.223570 [ 24367 ] {e4961489-4a7a-48b4-bd56-4b75cb370255} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 200, line 206) (in query: SELECT t1.*, t2.* FROM t1 LEFT JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189dea4d 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.224573 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189dea4d 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.246858 [ 24367 ] {a2328ca9-a165-4826-8293-f4454f49b0fa} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 201, line 207) (in query: SELECT t1.*, t2.* FROM t1 RIGHT JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189dea4d 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.247909 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189dea4d 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.276870 [ 24367 ] {999dc0b0-9bbf-4ff8-abb9-b028effdf0cf} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 202, line 208) (in query: SELECT t1.*, t2.* FROM t1 FULL JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189dea4d 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.278164 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189dea4d 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.317303 [ 24367 ] {b1a97fb9-0b7b-49a5-bd1e-6539c6c7cd77} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 204, line 210) (in query: SELECT t1.*, t2.* FROM t1 LEFT JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.320439 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.371761 [ 24367 ] {96ea1160-d3f7-414e-b130-d228185b7e09} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 205, line 211) (in query: SELECT t1.*, t2.* FROM t1 RIGHT JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.373711 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.402945 [ 24367 ] {d77004f3-44ac-4ea9-84e4-6b5d269dd6f0} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 206, line 212) (in query: SELECT t1.*, t2.* FROM t1 FULL JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.404229 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.438825 [ 24367 ] {e86612f7-f8c3-40f5-af9d-4935bb069842} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 208, line 214) (in query: SELECT t1.*, t2.* FROM t1 LEFT JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.439995 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.491277 [ 24367 ] {4ba00a2f-7d19-4bed-b409-c4436805f066} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 209, line 215) (in query: SELECT t1.*, t2.* FROM t1 RIGHT JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.492562 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.540001 [ 24367 ] {5bc843bf-e31e-49b5-94a8-84e231c65c6f} executeQuery: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55248) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 210, line 216) (in query: SELECT t1.*, t2.* FROM t1 FULL JOIN t2 ON t1.key = t2.key AND t1.a < t2.a OR t1.a = t2.a ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:13.541211 [ 24367 ] {} TCPHandler: Code: 48. DB::Exception: JOIN with mixed conditions supports only hash join or grace hash join. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1233: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de9c7 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:18:16.489316 [ 16822 ] {96af98ee-c65c-43ff-be9a-d4d09a921309} executeQuery: Code: 184. DB::Exception: Aggregate function sum(marks) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60246) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (query 5, line 9) (in query: SELECT ignore(toFixedString('Lambda as function parameter', 28), toNullable(28), ignore(8)), sum(marks) FROM system.parts WHERE database = currentDatabase() GROUP BY GROUPING SETS ((2)) FORMAT Null settings optimize_injective_functions_in_group_by=1, optimize_group_by_function_keys=1, group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 7. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af22b9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:18:16.495255 [ 16822 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function sum(marks) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 7. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af22b9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:18:17.085581 [ 16822 ] {ad1acf54-0875-4b13-97ad-4a1e3501ceea} executeQuery: Code: 184. DB::Exception: Aggregate function count('Lambda as function parameter') AS c is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60246) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (query 15, line 49) (in query: SELECT count('Lambda as function parameter') AS c FROM (SELECT ignore(ignore('Lambda as function parameter', 28, 28, 28, 28, 28, 28), 28), materialize('Lambda as function parameter'), 28, 28, 'world', 5 FROM system.numbers WHERE ignore(materialize('Lambda as function parameter'), materialize(toLowCardinality(28)), 28, 28, 28, 28, toUInt128(28)) LIMIT 2) GROUP BY GROUPING SETS ((toLowCardinality(0)), (toLowCardinality(toNullable(28))), (1)) HAVING nullIf(c, 10) < 50 ORDER BY c ASC NULLS FIRST settings group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 7. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af22b9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:18:17.088735 [ 16822 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function count('Lambda as function parameter') AS c is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000a1ecc46 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6ff4 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af6f71 7. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000017af72c3 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af22b9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:18:17.587248 [ 16822 ] {7337226d-099f-4cc9-9ef6-8efefafd63b0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Array(Nothing)) of argument of function toUInt8: while executing 'FUNCTION toUInt8(number :: 0) -> toUInt8(number) UInt8 : 1': while executing 'FUNCTION arraySplit(number Array(Array(Nothing)) -> toUInt8(number) :: 1, array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String))) :: 2) -> arraySplit(number Array(Array(Nothing)) -> toUInt8(number), array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String)))) Array(Array(Array(Array(Nothing)))) : 4'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60246) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (query 19, line 57) (in query: SELECT count(arraySplit(number -> toUInt8(number), [arraySplit(x -> toUInt8(number), [])])) FROM numbers(10) GROUP BY number, [number] WITH ROLLUP settings group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161e8127 5. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161e74e0 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 12. ./src/Functions/FunctionsMiscellaneous.h:67: DB::ExecutableFunctionExpression::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017a0cbc5 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 17. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x000000001a4b5e02 18. DB::FunctionArrayMapped, DB::NameArraySplit>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001051c638 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 25. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 2025.07.28 06:18:17.596909 [ 16822 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Array(Nothing)) of argument of function toUInt8: while executing 'FUNCTION toUInt8(number :: 0) -> toUInt8(number) UInt8 : 1': while executing 'FUNCTION arraySplit(number Array(Array(Nothing)) -> toUInt8(number) :: 1, array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String))) :: 2) -> arraySplit(number Array(Array(Nothing)) -> toUInt8(number), array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String)))) Array(Array(Array(Array(Nothing)))) : 4'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161e8127 5. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161e74e0 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 12. ./src/Functions/FunctionsMiscellaneous.h:67: DB::ExecutableFunctionExpression::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017a0cbc5 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 17. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x000000001a4b5e02 18. DB::FunctionArrayMapped, DB::NameArraySplit>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001051c638 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 25. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:21.285526 [ 2095 ] {cf789066-e891-4e98-8b9e-ddb3cf975fb7} executeQuery: Code: 43. DB::Exception: Parameter #0 'scale' for DateTime64 has wrong type: String, expected UInt64 literal: In scope SELECT CAST(1, 'DateTime64(\'abc\')'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54888) (comment: 00921_datetime64_basic.sql) (query 2, line 3) (in query: SELECT CAST(1 as DateTime64('abc'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/DataTypes/registerDataTypeDateTime.cpp:50: std::conditional<(DB::ArgumentKind)1 == (DB::ArgumentKind)0, std::optional, unsigned long>::type DB::getArgument(std::shared_ptr const&, unsigned long, char const*, String) @ 0x000000001750b85a 4. ./build_docker/./src/DataTypes/registerDataTypeDateTime.cpp:103: DB::create64(std::shared_ptr const&) @ 0x000000001750adcc 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000001742fdae 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:35: DB::DataTypeFactory::get(String const&) const @ 0x000000001742db41 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fad824 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:18:21.291417 [ 16819 ] {55c6f30d-9281-4d4e-8fa5-4f315f5e526f} executeQuery: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from: In scope SELECT transform('hello', 'wrong', 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54862) (comment: 00153_transform.sql) (query 15, line 15) (in query: SELECT transform('hello', 'wrong', 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef36ca0 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:18:21.293955 [ 2095 ] {} TCPHandler: Code: 43. DB::Exception: Parameter #0 'scale' for DateTime64 has wrong type: String, expected UInt64 literal: In scope SELECT CAST(1, 'DateTime64(\'abc\')'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/DataTypes/registerDataTypeDateTime.cpp:50: std::conditional<(DB::ArgumentKind)1 == (DB::ArgumentKind)0, std::optional, unsigned long>::type DB::getArgument(std::shared_ptr const&, unsigned long, char const*, String) @ 0x000000001750b85a 4. ./build_docker/./src/DataTypes/registerDataTypeDateTime.cpp:103: DB::create64(std::shared_ptr const&) @ 0x000000001750adcc 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000001742fdae 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:35: DB::DataTypeFactory::get(String const&) const @ 0x000000001742db41 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fad824 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:18:21.297581 [ 16819 ] {} TCPHandler: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from: In scope SELECT transform('hello', 'wrong', 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef36ca0 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:18:21.450935 [ 16819 ] {e403c4c5-357b-4955-913f-9a1e362d39d8} executeQuery: Code: 43. DB::Exception: Third argument of function transform, must be array of destination values to transform to: In scope SELECT transform('hello', ['wrong'], 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54862) (comment: 00153_transform.sql) (query 16, line 16) (in query: SELECT transform('hello', ['wrong'], 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef36d55 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:18:21.452148 [ 16819 ] {} TCPHandler: Code: 43. DB::Exception: Third argument of function transform, must be array of destination values to transform to: In scope SELECT transform('hello', ['wrong'], 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef36d55 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:18:21.452149 [ 2095 ] {f8a618b8-3a4f-4cda-a929-8401f934068d} executeQuery: Code: 69. DB::Exception: Scale 100 is out of bounds (max scale: 18): In scope SELECT CAST(1, 'DateTime64(100)'). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54888) (comment: 00921_datetime64_basic.sql) (query 3, line 4) (in query: SELECT CAST(1 as DateTime64(100));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000087e9026 4. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000017420334 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:21: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000001741d2b1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], unsigned long const&, String, 0>(std::allocator const&, unsigned long const&, String&&) @ 0x000000001750b1d5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create64(std::shared_ptr const&) @ 0x000000001750af25 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 10. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000001742fdae 11. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:35: DB::DataTypeFactory::get(String const&) const @ 0x000000001742db41 12. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fad824 13. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:18:21.458018 [ 2095 ] {} TCPHandler: Code: 69. DB::Exception: Scale 100 is out of bounds (max scale: 18): In scope SELECT CAST(1, 'DateTime64(100)'). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000087e9026 4. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000017420334 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:21: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000001741d2b1 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], unsigned long const&, String, 0>(std::allocator const&, unsigned long const&, String&&) @ 0x000000001750b1d5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create64(std::shared_ptr const&) @ 0x000000001750af25 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 10. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000001742fdae 11. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:35: DB::DataTypeFactory::get(String const&) const @ 0x000000001742db41 12. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fad824 13. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 14. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 15. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:18:21.469358 [ 16819 ] {19349781-7301-4bc0-a32f-8f159a4d7c69} executeQuery: Code: 43. DB::Exception: Function transform has signature: transform(T, Array(T), Array(U), U) -> U; or transform(T, Array(T), Array(T)) -> T; where T and U are types: In scope SELECT transform('hello', ['wrong'], [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54862) (comment: 00153_transform.sql) (query 17, line 17) (in query: SELECT transform('hello', ['wrong'], [1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef370f2 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:18:21.472731 [ 16819 ] {} TCPHandler: Code: 43. DB::Exception: Function transform has signature: transform(T, Array(T), Array(U), U) -> U; or transform(T, Array(T), Array(T)) -> T; where T and U are types: In scope SELECT transform('hello', ['wrong'], [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef370f2 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:18:21.474720 [ 2095 ] {21f35ff1-1c0b-4480-84a5-5a44ab80819c} executeQuery: Code: 43. DB::Exception: Parameter #0 'scale' for DateTime64 has wrong type: Int64, expected UInt64 literal: In scope SELECT CAST(1, 'DateTime64(-1)'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54888) (comment: 00921_datetime64_basic.sql) (query 4, line 5) (in query: SELECT CAST(1 as DateTime64(-1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/DataTypes/registerDataTypeDateTime.cpp:50: std::conditional<(DB::ArgumentKind)1 == (DB::ArgumentKind)0, std::optional, unsigned long>::type DB::getArgument(std::shared_ptr const&, unsigned long, char const*, String) @ 0x000000001750b85a 4. ./build_docker/./src/DataTypes/registerDataTypeDateTime.cpp:103: DB::create64(std::shared_ptr const&) @ 0x000000001750adcc 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000001742fdae 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:35: DB::DataTypeFactory::get(String const&) const @ 0x000000001742db41 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fad824 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:18:21.478721 [ 2095 ] {} TCPHandler: Code: 43. DB::Exception: Parameter #0 'scale' for DateTime64 has wrong type: Int64, expected UInt64 literal: In scope SELECT CAST(1, 'DateTime64(-1)'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/DataTypes/registerDataTypeDateTime.cpp:50: std::conditional<(DB::ArgumentKind)1 == (DB::ArgumentKind)0, std::optional, unsigned long>::type DB::getArgument(std::shared_ptr const&, unsigned long, char const*, String) @ 0x000000001750b85a 4. ./build_docker/./src/DataTypes/registerDataTypeDateTime.cpp:103: DB::create64(std::shared_ptr const&) @ 0x000000001750adcc 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000001742fdae 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:35: DB::DataTypeFactory::get(String const&) const @ 0x000000001742db41 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fad824 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:18:21.487435 [ 16819 ] {c95055e7-2d08-4c2c-9d6f-9ccad574db45} executeQuery: Code: 43. DB::Exception: Function transform has signature: transform(T, Array(T), Array(U), U) -> U; or transform(T, Array(T), Array(T)) -> T; where T and U are types: In scope SELECT transform(tuple(1), ['sdf'], [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54862) (comment: 00153_transform.sql) (query 18, line 18) (in query: SELECT transform(tuple(1), ['sdf'], [1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef370f2 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:18:21.490824 [ 16819 ] {} TCPHandler: Code: 43. DB::Exception: Function transform has signature: transform(T, Array(T), Array(U), U) -> U; or transform(T, Array(T), Array(T)) -> T; where T and U are types: In scope SELECT transform(tuple(1), ['sdf'], [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef370f2 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:18:21.737335 [ 2095 ] {3dee7987-aef3-44b5-9059-b45fd2fdab9e} executeQuery: Code: 36. DB::Exception: Cannot load time zone qqq: In scope SELECT CAST(1, 'DateTime64(3, \'qqq\')'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54888) (comment: 00921_datetime64_basic.sql) (query 5, line 6) (in query: SELECT CAST(1 as DateTime64(3, 'qqq'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000001741d2bd 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], unsigned long const&, String, 0>(std::allocator const&, unsigned long const&, String&&) @ 0x000000001750b1d5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create64(std::shared_ptr const&) @ 0x000000001750af25 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 12. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000001742fdae 13. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:35: DB::DataTypeFactory::get(String const&) const @ 0x000000001742db41 14. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fad824 15. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 16. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 17. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 2025.07.28 06:18:21.738945 [ 2095 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone qqq: In scope SELECT CAST(1, 'DateTime64(3, \'qqq\')'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000001741d2bd 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], unsigned long const&, String, 0>(std::allocator const&, unsigned long const&, String&&) @ 0x000000001750b1d5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create64(std::shared_ptr const&) @ 0x000000001750af25 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:ne190107] (*)(std::shared_ptr const&), std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000174172c4 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000017430227 12. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x000000001742fdae 13. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:35: DB::DataTypeFactory::get(String const&) const @ 0x000000001742db41 14. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fad824 15. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 16. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 17. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 2025.07.28 06:18:24.566270 [ 1859 ] {0bdd2ec5-306c-44d0-bb36-3310ea8fef2b} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Nullable(UInt8)): While executing AggregatingTransform. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55000) (comment: 02419_contingency_array_nullable.sql) (query 1, line 1) (in query: SELECT contingency(1, [1, NULL]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000001a2f149d 5. ./src/AggregateFunctions/UniqVariadicHash.h:49: DB::IAggregateFunctionHelper>::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000135c89cd 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1365: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x00000000183b6d1a 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1575: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b94c8 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:18:24.594373 [ 1859 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Nullable(UInt8)): While executing AggregatingTransform. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000001a2f149d 5. ./src/AggregateFunctions/UniqVariadicHash.h:49: DB::IAggregateFunctionHelper>::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000135c89cd 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1365: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x00000000183b6d1a 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1575: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b94c8 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:24.695045 [ 2095 ] {1e8e8bf8-978c-4368-8b8a-2f72120e02d7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: String: In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54888) (comment: 00921_datetime64_basic.sql) (query 6, line 8) (in query: SELECT toDateTime64('2019-09-16 19:20:11.234', 'abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000001620739e 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000163160c9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016206f44 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000162070c2 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:18:24.750854 [ 2095 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: String: In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000001620739e 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000163160c9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016206f44 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000162070c2 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:18:25.669934 [ 2095 ] {0f94b704-d84b-4cee-9b29-a9fc76f42a20} executeQuery: Code: 69. DB::Exception: Scale 100 is out of bounds (max scale: 18): In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 100). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54888) (comment: 00921_datetime64_basic.sql) (query 7, line 9) (in query: SELECT toDateTime64('2019-09-16 19:20:11.234', 100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000087e9026 4. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000017420334 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:21: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000001741d2b1 6. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x000000000eef55b5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000016207400 8. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000163160c9 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016206f44 10. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000162070c2 11. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:18:25.673591 [ 2095 ] {} TCPHandler: Code: 69. DB::Exception: Scale 100 is out of bounds (max scale: 18): In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 100). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000087e9026 4. ./src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000017420334 5. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:21: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000001741d2b1 6. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x000000000eef55b5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000016207400 8. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000163160c9 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016206f44 10. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000162070c2 11. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:18:25.735998 [ 2095 ] {000a3e1b-456a-4e62-9aea-be079dbbdd94} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: UInt64: In scope SELECT toDateTime64(CAST([['CLb5Ph ']], 'String'), uniqHLL12('2Gs1V', 752)). (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54888) (comment: 00921_datetime64_basic.sql) (query 8, line 10) (in query: SELECT toDateTime64(CAST([['CLb5Ph ']], 'String'), uniqHLL12('2Gs1V', 752));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000001620739e 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000163160c9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016206f44 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000162070c2 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:18:25.738083 [ 2095 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: UInt64: In scope SELECT toDateTime64(CAST([['CLb5Ph ']], 'String'), uniqHLL12('2Gs1V', 752)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000001620739e 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000163160c9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016206f44 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000162070c2 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:18:25.970003 [ 2095 ] {1ee7023f-dee0-40ae-a89d-1ea2d41d6429} executeQuery: Code: 36. DB::Exception: Cannot load time zone qqq: In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 3, 'qqq'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54888) (comment: 00921_datetime64_basic.sql) (query 9, line 11) (in query: SELECT toDateTime64('2019-09-16 19:20:11.234', 3, 'qqq');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000001741d2bd 8. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x000000000eef55b5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000016207400 10. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000163160c9 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016206f44 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000162070c2 13. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 14. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 15. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 16. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:18:25.974194 [ 2095 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone qqq: In scope SELECT toDateTime64('2019-09-16 19:20:11.234', 3, 'qqq'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000001741d2bd 8. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String, 0>(std::allocator const&, unsigned int&, String&&) @ 0x000000000eef55b5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::detail::FunctionConvert::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000016207400 10. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000163160c9 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016206f44 12. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert::getReturnTypeImpl(std::vector> const&) const @ 0x00000000162070c2 13. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 14. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 15. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 16. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:18:26.212934 [ 2095 ] {05e7f93d-11bf-4d0a-b3cf-cf458dcf6923} executeQuery: Code: 43. DB::Exception: Illegal type UInt64 of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64(gccMurmurHash())). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54888) (comment: 00921_datetime64_basic.sql) (query 10, line 13) (in query: SELECT ignore(now64(gccMurmurHash()));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df1c533 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:18:26.215657 [ 2095 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt64 of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64(gccMurmurHash())). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df1c533 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:18:26.235981 [ 2095 ] {c47dac65-cc6a-4442-bf03-3d5f453f3771} executeQuery: Code: 43. DB::Exception: Illegal type String of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64('abcd')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54888) (comment: 00921_datetime64_basic.sql) (query 11, line 14) (in query: SELECT ignore(now64('abcd'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df1c533 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:18:26.238442 [ 2095 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64('abcd')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df1c533 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:18:26.265264 [ 2095 ] {41659380-c2bd-4d04-b07b-0c02f06db2b3} executeQuery: Code: 43. DB::Exception: Illegal type UInt64 of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64(number)) FROM system.numbers LIMIT 10. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54888) (comment: 00921_datetime64_basic.sql) (query 12, line 15) (in query: SELECT ignore(now64(number)) FROM system.numbers LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df1c533 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:18:26.267055 [ 2095 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt64 of 0 argument of function now64. Expected const integer.: In scope SELECT ignore(now64(number)) FROM system.numbers LIMIT 10. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df1c533 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:18:26.441599 [ 2095 ] {285922ca-9b2f-43bd-b52b-bfb81e86e616} executeQuery: Code: 36. DB::Exception: Cannot load time zone invalid timezone: In scope SELECT ignore(now64(3, 'invalid timezone')). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54888) (comment: 00921_datetime64_basic.sql) (query 13, line 16) (in query: SELECT ignore(now64(3, 'invalid timezone'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000001741d2bd 8. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String&, 0>(std::allocator const&, unsigned int&, String&) @ 0x000000000cad79d5 9. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df1c44c 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:18:26.444185 [ 2095 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone invalid timezone: In scope SELECT ignore(now64(3, 'invalid timezone')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x0000000010b0f698 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x0000000010b0a667 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000001741cdba 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000001741d2bd 8. std::shared_ptr std::allocate_shared[abi:ne190107], unsigned int&, String&, 0>(std::allocator const&, unsigned int&, String&) @ 0x000000000cad79d5 9. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df1c44c 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:18:26.612041 [ 2095 ] {1f4a8cbe-2d18-4547-b941-36e5e860d71e} executeQuery: Code: 44. DB::Exception: Illegal column 1111 of time zone argument of function, must be a constant string: In scope SELECT ignore(now64(3, 1111)). (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:54888) (comment: 00921_datetime64_basic.sql) (query 14, line 17) (in query: SELECT ignore(now64(3, 1111));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x0000000016451958 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x0000000016451b92 6. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df1c429 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:18:26.615189 [ 2095 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column 1111 of time zone argument of function, must be a constant string: In scope SELECT ignore(now64(3, 1111)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::extractTimeZoneNameFromColumn(DB::IColumn const*, String const&) @ 0x0000000016451958 5. DB::extractTimeZoneNameFromFunctionArguments(std::vector> const&, unsigned long, unsigned long, bool) @ 0x0000000016451b92 6. DB::(anonymous namespace)::Now64OverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df1c429 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:18:35.252622 [ 24367 ] {e5f61cc0-ddd0-4aea-8f85-40a08cc8b993} executeQuery: Code: 469. DB::Exception: Constraint `cs_value2` for table test_gcizbynh.table_for_rename1 (5bc0f7cb-4110-4641-83b4-2a34ccb66f90) is violated at row 1. Expression: (toInt64(value2) < toInt64(value3)). Column values: value2 = '1', value3 = '0'. (VIOLATED_CONSTRAINT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55420) (comment: 01277_alter_rename_column_constraint_zookeeper_long.sql) (query 4, line 20) (in query: INSERT INTO table_for_rename1 SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number + 1), toString(number) from numbers(9);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:18:35.321712 [ 24367 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value2` for table test_gcizbynh.table_for_rename1 (5bc0f7cb-4110-4641-83b4-2a34ccb66f90) is violated at row 1. Expression: (toInt64(value2) < toInt64(value3)). Column values: value2 = '1', value3 = '0'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:37.156399 [ 1865 ] {d7370f80-3e49-4386-942a-57e9423a737e} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.28 06:18:37.502564 [ 24367 ] {e89bd635-c083-4328-9270-ff9b3b1f6bc1} executeQuery: Code: 469. DB::Exception: Constraint `cs_value2` for table test_gcizbynh.table_for_rename1 (5bc0f7cb-4110-4641-83b4-2a34ccb66f90) is violated at row 1. Expression: (toInt64(value5) < toInt64(value3)). Column values: value5 = '11', value3 = '10'. (VIOLATED_CONSTRAINT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55420) (comment: 01277_alter_rename_column_constraint_zookeeper_long.sql) (query 12, line 31) (in query: INSERT INTO table_for_rename1 SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number + 1), toString(number) from numbers(10, 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:18:37.509099 [ 24367 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value2` for table test_gcizbynh.table_for_rename1 (5bc0f7cb-4110-4641-83b4-2a34ccb66f90) is violated at row 1. Expression: (toInt64(value5) < toInt64(value3)). Column values: value5 = '11', value3 = '10'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:37.841121 [ 1865 ] {d7370f80-3e49-4386-942a-57e9423a737e} Cluster: Code: 198. DB::NetException: Not found address of host: localhos. (DNS_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000010aead79 3. ./build_docker/./src/Common/DNSResolver.cpp:113: DB::(anonymous namespace)::hostByName(String const&) @ 0x0000000010ae66e3 4. ./build_docker/./src/Common/DNSResolver.cpp:138: DB::DNSResolver::getResolvedIPAdressessWithFiltering(String const&) @ 0x0000000010ae4cb3 5. ./build_docker/./src/Common/DNSResolver.cpp:256: DB::DNSResolver::resolveIPAddressWithCache(String const&) @ 0x0000000010ae5299 6. ./build_docker/./src/Common/DNSResolver.cpp:305: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x0000000010ae60df 7. ./build_docker/./src/Interpreters/Cluster.cpp:82: DB::Cluster::Address::getResolvedAddress() const @ 0x0000000018153381 8. ./build_docker/./src/Interpreters/Cluster.cpp:95: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x0000000018155947 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Address* std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x0000000018167be0 10. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001815fd8a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000013c8d9d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8aad6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:18:40.913265 [ 24367 ] {f0147b5d-3587-42b5-8fce-230ccd254c45} executeQuery: Code: 469. DB::Exception: Constraint `cs_value1` for table test_gcizbynh.table_for_rename1 (5bc0f7cb-4110-4641-83b4-2a34ccb66f90) is violated at row 1. Expression: (toInt64(value1) < toInt64(value2)). Column values: value1 = '20', value2 = '20'. (VIOLATED_CONSTRAINT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55420) (comment: 01277_alter_rename_column_constraint_zookeeper_long.sql) (query 21, line 42) (in query: INSERT INTO table_for_rename1 SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number), toString(number + 2) from numbers(20, 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:18:40.929008 [ 24367 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value1` for table test_gcizbynh.table_for_rename1 (5bc0f7cb-4110-4641-83b4-2a34ccb66f90) is violated at row 1. Expression: (toInt64(value1) < toInt64(value2)). Column values: value1 = '20', value2 = '20'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000017597a7c 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000001c09bafd 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0586 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afbf5 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:43.598475 [ 2054 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33198) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:43.605388 [ 2054 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:44.145997 [ 16973 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33224) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:44.153909 [ 16973 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:44.669693 [ 2095 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33244) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:44.679152 [ 2095 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:45.156957 [ 16973 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33290) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:45.165849 [ 16973 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:45.775752 [ 16973 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-5} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33302) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:45.791971 [ 16973 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:46.127975 [ 1422 ] {d7370f80-3e49-4386-942a-57e9423a737e} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.28 06:18:46.573089 [ 1859 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-6} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33346) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:46.580194 [ 1859 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:47.010394 [ 1865 ] {d7370f80-3e49-4386-942a-57e9423a737e} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 198. DB::NetException: Not found address of host: localhos: (localhos:9000). (DNS_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55252) (comment: 00965_shard_unresolvable_addresses.sql) (query 5, line 9) (in query: SELECT count() FROM remote('127.0.0.1,localhos', system.one);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 2025.07.28 06:18:47.122265 [ 1865 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 198. DB::NetException: Not found address of host: localhos: (localhos:9000). (DNS_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:47.391800 [ 1859 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39600) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:47.403843 [ 1859 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:47.479602 [ 16822 ] {c9344a30-4523-4fa3-ba51-7873f0b3ac6a} executeQuery: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is String. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33264) (comment: 03198_dictionary_validate_primary_key_type.sql) (query 3, line 12) (in query: CREATE DICTIONARY `test_dictionary1` ( `n1` String, `n2` UInt32 ) PRIMARY KEY n1 SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 DB 'test_db' TABLE 'table_01' USER 'default')) LIFETIME(MIN 1 MAX 10) LAYOUT(FLAT());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c056fc0 4. ./build_docker/./src/Storages/StorageDictionary.cpp:72: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x000000001aa73ac9 5. ./build_docker/./src/Storages/StorageDictionary.cpp:129: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x000000001aa740e1 6. ./build_docker/./src/Storages/StorageDictionary.cpp:140: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000001aa7437d 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000001aa78bfd 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001aa77c5d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:18:47.566317 [ 16822 ] {} TCPHandler: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is String. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c056fc0 4. ./build_docker/./src/Storages/StorageDictionary.cpp:72: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x000000001aa73ac9 5. ./build_docker/./src/Storages/StorageDictionary.cpp:129: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x000000001aa740e1 6. ./build_docker/./src/Storages/StorageDictionary.cpp:140: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000001aa7437d 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000001aa78bfd 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001aa77c5d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:18:47.642745 [ 16822 ] {b68c21ae-4904-48fb-8b1d-f980e2971cab} executeQuery: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is UInt32. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33264) (comment: 03198_dictionary_validate_primary_key_type.sql) (query 4, line 21) (in query: CREATE DICTIONARY `test_dictionary2` ( `n1` UInt32, `n2` UInt32 ) PRIMARY KEY n1 SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 DB 'test_db' TABLE 'table_01' USER 'default')) LIFETIME(MIN 1 MAX 10) LAYOUT(FLAT());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c056fc0 4. ./build_docker/./src/Storages/StorageDictionary.cpp:72: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x000000001aa73ac9 5. ./build_docker/./src/Storages/StorageDictionary.cpp:129: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x000000001aa740e1 6. ./build_docker/./src/Storages/StorageDictionary.cpp:140: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000001aa7437d 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000001aa78bfd 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001aa77c5d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:18:47.644922 [ 16822 ] {} TCPHandler: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is UInt32. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c056fc0 4. ./build_docker/./src/Storages/StorageDictionary.cpp:72: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x000000001aa73ac9 5. ./build_docker/./src/Storages/StorageDictionary.cpp:129: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x000000001aa740e1 6. ./build_docker/./src/Storages/StorageDictionary.cpp:140: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000001aa7437d 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000001aa78bfd 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001aa77c5d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:18:48.015400 [ 1808 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39630) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:48.035071 [ 1808 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:48.589449 [ 1851 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39640) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:48.619503 [ 1851 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:49.260666 [ 24374 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-10} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39672) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:49.268958 [ 24374 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:49.664032 [ 1859 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-11} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39698) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:49.695344 [ 1859 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:49.748510 [ 1394 ] {889e626f-26db-495b-88bb-014169a967b0} StorageBuffer (test_6taiaiet.mt_buffer_00158): Destination table test_6taiaiet.mt_00158 doesn't exist. Block of data is discarded. 2025.07.28 06:18:49.788713 [ 17284 ] {889e626f-26db-495b-88bb-014169a967b0} StorageBuffer (test_6taiaiet.mt_buffer_00158): Destination table test_6taiaiet.mt_00158 doesn't exist. Block of data is discarded. 2025.07.28 06:18:50.336150 [ 1859 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-12} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39722) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:50.363059 [ 1859 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:51.029682 [ 1808 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-13} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39756) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:51.040633 [ 1808 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:51.626975 [ 1808 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-14} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39792) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:51.653817 [ 1808 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:52.293141 [ 1859 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-15} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39868) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:52.297062 [ 1859 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:53.254466 [ 16973 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-16} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39956) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:53.261330 [ 16973 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:53.968182 [ 24373 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-17} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40066) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:53.970219 [ 24373 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:54.132998 [ 631 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.28 06:18:54.641453 [ 1851 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-18} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40158) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:54.644115 [ 1851 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:55.209782 [ 16973 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-19} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40222) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:55.228294 [ 16973 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:55.592052 [ 1808 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-20} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40284) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:55.596577 [ 1808 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:56.258783 [ 1859 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-21} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40326) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:56.259588 [ 24367 ] {c2527fd2-5b92-4464-ba60-14e5c92d8261} executeQuery: Code: 354. DB::Exception: inflate failed: data error: While reading from: test/a.tsv: (while reading header): (in file/uri test/a.tsv): While executing TabSeparatedRowInputFormat: While executing S3(_table_function.s3)Source. (ZLIB_INFLATE_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40340) (comment: 02973_s3_compressed_file_in_error_message.sh) (query 1, line 1) (in query: select * from s3('http://localhost:11111/test/a.tsv', TSV, 'x String', 'gzip')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000000f139166 4. ./build_docker/./src/IO/ZlibInflatingReadBuffer.cpp:111: DB::ZlibInflatingReadBuffer::nextImpl() @ 0x0000000010efcad6 5. DB::ReadBuffer::next() @ 0x0000000008915c7b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x0000000010c58e76 7. DB::ReadBuffer::next() @ 0x0000000008915c7b 8. ./src/IO/ReadBuffer.h:96: DB::TabSeparatedFormatReader::checkForSuffix() @ 0x000000001c03a9c1 9. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:164: DB::RowInputFormatWithNamesAndTypes::tryDetectHeader(std::vector>&, std::vector>&) @ 0x000000001bdfaa32 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:109: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001bdfa0b5 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000001bdbcff8 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 19. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:233: DB::StorageObjectStorageSource::generate() @ 0x000000001665e99a 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 26. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:18:56.261323 [ 1859 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:56.275865 [ 24367 ] {} TCPHandler: Code: 354. DB::Exception: inflate failed: data error: While reading from: test/a.tsv: (while reading header): (in file/uri test/a.tsv): While executing TabSeparatedRowInputFormat: While executing S3(_table_function.s3)Source. (ZLIB_INFLATE_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000000f139166 4. ./build_docker/./src/IO/ZlibInflatingReadBuffer.cpp:111: DB::ZlibInflatingReadBuffer::nextImpl() @ 0x0000000010efcad6 5. DB::ReadBuffer::next() @ 0x0000000008915c7b 6. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x0000000010c58e76 7. DB::ReadBuffer::next() @ 0x0000000008915c7b 8. ./src/IO/ReadBuffer.h:96: DB::TabSeparatedFormatReader::checkForSuffix() @ 0x000000001c03a9c1 9. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:164: DB::RowInputFormatWithNamesAndTypes::tryDetectHeader(std::vector>&, std::vector>&) @ 0x000000001bdfaa32 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:109: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000001bdfa0b5 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:97: DB::IRowInputFormat::read() @ 0x000000001bdbcff8 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 19. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:233: DB::StorageObjectStorageSource::generate() @ 0x000000001665e99a 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 26. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:57.004748 [ 1860 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-22} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40422) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:57.035613 [ 1860 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:57.492841 [ 1851 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-23} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51924) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:57.498940 [ 1851 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:58.195652 [ 24374 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-24} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51952) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:58.203149 [ 24374 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:18:59.313797 [ 1867 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-25} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52026) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:18:59.339492 [ 1867 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:00.229133 [ 24367 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-26} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52062) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:00.253903 [ 24367 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:00.898468 [ 16819 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-27} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52146) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:00.915290 [ 16819 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:01.611421 [ 16973 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-28} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52196) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:01.641870 [ 16973 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:02.148160 [ 1865 ] {24761574-961b-4535-a9af-d4cf2eefa630} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.28 06:19:02.150951 [ 1865 ] {24761574-961b-4535-a9af-d4cf2eefa630} Cluster: Code: 198. DB::NetException: Not found address of host: localhos. (DNS_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000010aead79 3. ./build_docker/./src/Common/DNSResolver.cpp:113: DB::(anonymous namespace)::hostByName(String const&) @ 0x0000000010ae66e3 4. ./build_docker/./src/Common/DNSResolver.cpp:138: DB::DNSResolver::getResolvedIPAdressessWithFiltering(String const&) @ 0x0000000010ae4cb3 5. ./build_docker/./src/Common/DNSResolver.cpp:256: DB::DNSResolver::resolveIPAddressWithCache(String const&) @ 0x0000000010ae5299 6. ./build_docker/./src/Common/DNSResolver.cpp:305: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x0000000010ae60df 7. ./build_docker/./src/Interpreters/Cluster.cpp:82: DB::Cluster::Address::getResolvedAddress() const @ 0x0000000018153381 8. ./build_docker/./src/Interpreters/Cluster.cpp:95: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x0000000018155947 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Address* std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x0000000018167be0 10. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001815fd8a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000013c8d9d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8aad6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:19:02.326901 [ 24373 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-29} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52228) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:02.362670 [ 24373 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:03.008270 [ 1867 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-30} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52254) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:03.041189 [ 1867 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:03.703095 [ 1851 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-31} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52294) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:03.706550 [ 1851 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:03.737038 [ 16819 ] {076fa61c-94f6-411b-ab37-94a1ff6fee91} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52170) (comment: 01002_alter_nullable_adaptive_granularity_long.sh) (query 1, line 1) (in query: INSERT INTO test SELECT rand() FROM numbers(1000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000001bc0554f 3. ./build_docker/./src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001bbfc176 4. ./build_docker/./src/Server/TCPHandler.cpp:693: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bc042ea 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001bd0ea40 6. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:19:03.860768 [ 16819 ] {076fa61c-94f6-411b-ab37-94a1ff6fee91} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:52170). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d883af 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2558: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000001bbe8f95 7. ./build_docker/./src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x000000001bbdaef1 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:19:03.865795 [ 16819 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000001bc0554f 3. ./build_docker/./src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001bbfc176 4. ./build_docker/./src/Server/TCPHandler.cpp:693: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bc042ea 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001bd0ea40 6. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:19:04.166169 [ 2054 ] {f964a63d-1991-4213-8ac6-9f296eae74d1} executeQuery: Code: 397. DB::Exception: MATERIALIZED VIEW support query with multiple simple UNION [ALL] only. (QUERY_IS_NOT_SUPPORTED_IN_MATERIALIZED_VIEW) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52270) (comment: 03247_materialized_view_select_intersect.sql) (query 1, line 1) (in query: CREATE MATERIALIZED VIEW v0 AS (SELECT 1) INTERSECT (SELECT 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/SelectQueryDescription.cpp:82: DB::(anonymous namespace)::checkAllowedQueries(DB::ASTSelectWithUnionQuery const&) @ 0x000000001aa6cfee 5. ./build_docker/./src/Storages/SelectQueryDescription.cpp:113: DB::SelectQueryDescription::getSelectQueryFromASTForMatView(std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000001aa6c94a 6. ./build_docker/./src/Storages/StorageMaterializedView.cpp:144: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&, bool) @ 0x000000001ab98c1f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, bool const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, bool const&) @ 0x000000001aba8b1d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001aba6591 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:19:04.175585 [ 2054 ] {} TCPHandler: Code: 397. DB::Exception: MATERIALIZED VIEW support query with multiple simple UNION [ALL] only. (QUERY_IS_NOT_SUPPORTED_IN_MATERIALIZED_VIEW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/SelectQueryDescription.cpp:82: DB::(anonymous namespace)::checkAllowedQueries(DB::ASTSelectWithUnionQuery const&) @ 0x000000001aa6cfee 5. ./build_docker/./src/Storages/SelectQueryDescription.cpp:113: DB::SelectQueryDescription::getSelectQueryFromASTForMatView(std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000001aa6c94a 6. ./build_docker/./src/Storages/StorageMaterializedView.cpp:144: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&, bool) @ 0x000000001ab98c1f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, bool const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, bool const&) @ 0x000000001aba8b1d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001aba6591 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:19:04.447029 [ 24373 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-32} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52302) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:04.463020 [ 24373 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:05.192260 [ 24374 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-33} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52362) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:05.201012 [ 24374 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:05.977765 [ 1860 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-34} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52396) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:05.984839 [ 1860 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:06.649293 [ 1860 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-35} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52456) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:06.654032 [ 1860 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:07.140411 [ 16819 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-36} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49532) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:07.149622 [ 16819 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:07.783621 [ 24373 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-37} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49574) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:07.786568 [ 24373 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:08.225337 [ 24379 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-38} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49614) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:08.228656 [ 24379 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:08.683625 [ 1851 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-39} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49656) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:08.701452 [ 1851 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:09.610174 [ 24379 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-40} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49698) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:09.639090 [ 24379 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:10.624044 [ 24374 ] {} TCPHandler: Code: 394. DB::Exception: Query '02450_kill_distributed_query_deadlock_test_jj9o4gf5-41' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e179d1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:19:11.156194 [ 1859 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-42} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49798) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:11.159868 [ 1859 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:11.803034 [ 1865 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-43} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49844) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:11.806282 [ 1865 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:12.278502 [ 16973 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-44} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49910) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:12.283846 [ 16973 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:12.737104 [ 16973 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-45} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49944) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000018ac7caf 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000001bd0f98d 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24c01 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 10. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 11. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:19:12.739094 [ 16973 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000018ac7caf 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000001bd0f98d 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24c01 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 10. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 11. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:19:13.075812 [ 1867 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-46} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49996) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:13.078981 [ 1867 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:13.921827 [ 1851 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-47} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:50028) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:13.932675 [ 1851 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:14.532519 [ 1808 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-48} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:50090) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:14.537192 [ 1808 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:15.140425 [ 1851 ] {02450_kill_distributed_query_deadlock_test_jj9o4gf5-49} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:50164) (comment: 02450_kill_distributed_query_deadlock.sh) (query 1, line 1) (in query: select * from remote('127.{1|2|3|4|5|6}', numbers(1e12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:15.146840 [ 1851 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:15.533922 [ 24367 ] {} TCPHandler: Code: 394. DB::Exception: Query '02450_kill_distributed_query_deadlock_test_jj9o4gf5-50' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e179d1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:19:16.883774 [ 17177 ] {031c14b5-dafa-4bf7-9c6f-1553ea76eeae} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: x: (at row 1) . (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000088dac80 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:806: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001bdd8865 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 9. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001bf46e17 10. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001bf4509e 11. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bf484f8 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000001bf4669d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000001bf4459d 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000001bf49950 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bf49802 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000001bf47c02 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000001bf46477 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001bd27481 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013d056ab 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 16. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 32. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 33. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 34. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 35. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 36. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 37. __tsan_thread_start_func @ 0x0000000008756428 38. ? @ 0x00007fecd6763ac3 39. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:19:16.886887 [ 1865 ] {031c14b5-dafa-4bf7-9c6f-1553ea76eeae} executeQuery: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: x: (at row 1) : While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:50238) (comment: 02590_bson_duplicate_column.sql) (query 1, line 1) (in query: select * from format(BSONEachRow, 'x UInt32, y UInt32', x'1a0000001078002a0000001078002a0000001079002a00000000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000088dac80 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:806: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001bdd8865 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 9. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001bf46e17 10. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001bf4509e 11. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bf484f8 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:19:16.889221 [ 1865 ] {} TCPHandler: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: x: (at row 1) : While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x00000000088dac80 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:806: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001bdd8865 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 9. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001bf46e17 10. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001bf4509e 11. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bf484f8 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000001bf4669d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000001bf4459d 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000001bf49950 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bf49802 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000001bf47c02 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000001bf46477 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001bd27481 14. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013d056ab 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 16. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 32. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 33. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 34. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 35. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 36. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 37. __tsan_thread_start_func @ 0x0000000008756428 38. ? @ 0x00007fecd6763ac3 39. ? @ 0x00007fecd67f5850 2025.07.28 06:19:17.147528 [ 611 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.28 06:19:17.875589 [ 1808 ] {2c9c2ee6-3c0f-43b0-bc0f-eb218f3545fa} OptimizeRegularExpression: Analyze RegularExpression failed, got error: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7fe97a5c0000, frame address: 0x7fe97ad59840, stack size: 419776, maximum stack size: 8388608. (TOO_DEEP_RECURSION) (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:19:18.337267 [ 1808 ] {2c9c2ee6-3c0f-43b0-bc0f-eb218f3545fa} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((, error: missing ): ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT match('', repeat('(', 100000)). (CANNOT_COMPILE_REGEXP) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39846) (comment: 02831_regexp_analyze_recursion.sql) (query 1, line 1) (in query: SELECT match('', repeat('(', 100000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000087ec0e6 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000010bbf7d7 5. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000000cae5077 6. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cae1dec 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:19:18.428900 [ 1808 ] {} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((, error: missing ): ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT match('', repeat('(', 100000)). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000087ec0e6 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000010bbf7d7 5. std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000000cae5077 6. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cae1dec 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:19:20.270028 [ 1851 ] {8e5ee2a6-aa1a-4389-af6d-1d802bef41e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsHorizontal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39944) (comment: 01246_extractAllGroupsHorizontal.sql) (query 1, line 1) (in query: -- error cases SELECT extractAllGroupsHorizontal();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:19:20.276548 [ 1851 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsHorizontal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:19:20.300556 [ 1851 ] {dc574ed1-9e8a-4252-a706-a7316de1cd53} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsHorizontal('hello'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39944) (comment: 01246_extractAllGroupsHorizontal.sql) (query 2, line 3) (in query: SELECT extractAllGroupsHorizontal('hello');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:19:20.307146 [ 1851 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 1, should be 2: In scope SELECT extractAllGroupsHorizontal('hello'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:19:20.527783 [ 1851 ] {37a12a0e-32ec-4d80-b5ef-878baa39e584} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractAllGroupsHorizontal'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractAllGroupsHorizontal('hello', 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39944) (comment: 01246_extractAllGroupsHorizontal.sql) (query 3, line 4) (in query: SELECT extractAllGroupsHorizontal('hello', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aaf2784 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:19:20.532721 [ 1851 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractAllGroupsHorizontal'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractAllGroupsHorizontal('hello', 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aaf2784 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:19:20.547148 [ 1851 ] {5bd6a4ff-f97d-47a8-a25b-91b92a1ce6e1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractAllGroupsHorizontal'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractAllGroupsHorizontal(123, 'world'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39944) (comment: 01246_extractAllGroupsHorizontal.sql) (query 4, line 5) (in query: SELECT extractAllGroupsHorizontal(123, 'world');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aaf2784 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:19:20.552150 [ 1851 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractAllGroupsHorizontal'. Expected: const String or const FixedString, got: UInt8: In scope SELECT extractAllGroupsHorizontal(123, 'world'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aaf2784 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:19:20.715491 [ 1851 ] {145f4d59-ffd7-445a-a0c4-985b610a2a31} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (((, error: missing ): (((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT extractAllGroupsHorizontal('hello world', '((('). (CANNOT_COMPILE_REGEXP) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39944) (comment: 01246_extractAllGroupsHorizontal.sql) (query 5, line 6) (in query: SELECT extractAllGroupsHorizontal('hello world', '(((');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000087ec0e6 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000010bbf7d7 5. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf0c54 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:19:20.721583 [ 1851 ] {} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (((, error: missing ): (((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT extractAllGroupsHorizontal('hello world', '((('). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000087ec0e6 4. ./build_docker/./src/Common/OptimizedRegularExpression.cpp:518: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x0000000010bbf7d7 5. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf0c54 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:19:20.733036 [ 1851 ] {e9da7bd9-e906-4b14-b86b-258843b680f3} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractAllGroupsHorizontal'. Expected: const String or const FixedString, got: String: In scope SELECT extractAllGroupsHorizontal('hello world', materialize('\\w+')). (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39944) (comment: 01246_extractAllGroupsHorizontal.sql) (query 6, line 7) (in query: SELECT extractAllGroupsHorizontal('hello world', materialize('\\w+'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aaf2784 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:19:20.733951 [ 1851 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'needle' to function 'extractAllGroupsHorizontal'. Expected: const String or const FixedString, got: String: In scope SELECT extractAllGroupsHorizontal('hello world', materialize('\\w+')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aaf2784 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:19:20.895625 [ 1851 ] {e2779d6f-1030-4212-8e67-0a7927c1e7d1} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: \w+: In scope SELECT extractAllGroupsHorizontal('hello world', '\\w+'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39944) (comment: 01246_extractAllGroupsHorizontal.sql) (query 7, line 8) (in query: SELECT extractAllGroupsHorizontal('hello world', '\\w+');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf2152 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:19:20.901060 [ 1851 ] {} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: \w+: In scope SELECT extractAllGroupsHorizontal('hello world', '\\w+'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf2152 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:19:21.028104 [ 1851 ] {d74bbb6f-073c-43a8-af1d-1ed1f29da7f7} executeQuery: Code: 128. DB::Exception: Too many matches per row (> 0) in the result of function extractAllGroupsHorizontal: In scope SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 0. (TOO_LARGE_ARRAY_SIZE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39944) (comment: 01246_extractAllGroupsHorizontal.sql) (query 8, line 9) (in query: SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000aaf2986 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf1f98 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:19:21.030677 [ 1851 ] {} TCPHandler: Code: 128. DB::Exception: Too many matches per row (> 0) in the result of function extractAllGroupsHorizontal: In scope SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 0. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000aaf2986 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf1f98 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:19:21.040695 [ 1851 ] {5e284bf9-f064-4342-8840-3f40bbbb53fd} executeQuery: Code: 128. DB::Exception: Too many matches per row (> 1) in the result of function extractAllGroupsHorizontal: In scope SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 1. (TOO_LARGE_ARRAY_SIZE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39944) (comment: 01246_extractAllGroupsHorizontal.sql) (query 9, line 10) (in query: SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000aaf2986 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf1f98 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:19:21.044768 [ 1851 ] {} TCPHandler: Code: 128. DB::Exception: Too many matches per row (> 1) in the result of function extractAllGroupsHorizontal: In scope SELECT extractAllGroupsHorizontal('hello world', '(\\w+)') SETTINGS regexp_max_matches_per_row = 1. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000aaf2986 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaf1f98 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:19:26.055639 [ 24379 ] {ca205a50-efb2-41ac-9f86-df7321f291f1} executeQuery: Code: 36. DB::Exception: 'StorageFuzzJSON' supports only columns of String type, got Nullable(Int64). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40030) (comment: 02919_storage_fuzzjson.sql) (query 14, line 48) (in query: CREATE TABLE 02919_test_table_invalid_col_type ( str Nullable(Int64) ) ENGINE = FuzzJSON('{"pet":"rat"}', NULL);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/StorageFuzzJSON.cpp:735: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001aaec2b8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:19:26.057285 [ 1865 ] {a75d4997-e6fd-4f38-a700-6040f18e270b} executeQuery: Code: 344. DB::Exception: ALTER TABLE commands are not supported on immutable disk 'cont-03008-azure-plain-rewritable-test-z1ry0gh5', except for setting and comment alteration. (SUPPORT_IS_DISABLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40056) (comment: 03008_azure_plain_rewritable.sh) (query 1, line 2) (in query: alter table test_azure_mt add projection test_azure_mt_projection (select * order by b)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3560: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b3260c6 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:19:26.062969 [ 24379 ] {} TCPHandler: Code: 36. DB::Exception: 'StorageFuzzJSON' supports only columns of String type, got Nullable(Int64). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/StorageFuzzJSON.cpp:735: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001aaec2b8 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:19:26.065592 [ 1865 ] {} TCPHandler: Code: 344. DB::Exception: ALTER TABLE commands are not supported on immutable disk 'cont-03008-azure-plain-rewritable-test-z1ry0gh5', except for setting and comment alteration. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3560: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b3260c6 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:19:26.587840 [ 1860 ] {d53ff127-53ee-48d2-8c9e-1eed66be175d} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path. You can specify table structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40060) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_ub767igi_test1.`tmp_numbers_*.csv`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Storages/StorageFile.cpp:962: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab92ee 5. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 6. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 7. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabc85b 8. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001aabcf8f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000013cbd11d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000013cba627 11. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cbeb14 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 13. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:161: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000017675794 14. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 15. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 16. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 17. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:19:26.592757 [ 1860 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path. You can specify table structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Storages/StorageFile.cpp:962: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab92ee 5. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 6. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 7. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabc85b 8. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001aabcf8f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000013cbd11d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000013cba627 11. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cbeb14 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 13. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:161: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000017675794 14. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 15. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 16. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 17. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 2025.07.28 06:19:26.716446 [ 24373 ] {e4dcefa4-452d-4064-8d49-8e6d9ebb7351} executeQuery: Code: 344. DB::Exception: Mutations are not supported for immutable disk 'cont-03008-azure-plain-rewritable-test-z1ry0gh5'. (SUPPORT_IS_DISABLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40062) (comment: 03008_azure_plain_rewritable.sh) (query 1, line 2) (in query: alter table test_azure_mt update c = 0 where a % 2 = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3971: DB::MergeTreeData::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000001b330bc9 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:233: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fed7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:19:26.721933 [ 24373 ] {} TCPHandler: Code: 344. DB::Exception: Mutations are not supported for immutable disk 'cont-03008-azure-plain-rewritable-test-z1ry0gh5'. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3971: DB::MergeTreeData::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000001b330bc9 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:233: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fed7 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:19:27.667328 [ 2095 ] {c989706b-fe9d-47e9-9db2-1efa77c2517c} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51132) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_ub767igi_test1.`../tmp.csv`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000017674d6f 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x00000000176753da 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:27.671459 [ 2095 ] {} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000017674d6f 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x00000000176753da 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:28.194852 [ 2095 ] {c2f91e82-a049-40b4-839e-90c6db221e91} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51166) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_ub767igi_test1.`/tmp/tmp.csv`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000017674d6f 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x00000000176753da 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:28.201219 [ 2095 ] {} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000017674d6f 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x00000000176753da 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:28.710641 [ 2095 ] {cf598c29-5f4f-4d02-927f-b0065f2154d8} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51174) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_ub767igi_test1.`../*/tmp_numbers_*.csv`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000017674d6f 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x00000000176753da 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:28.724490 [ 2095 ] {} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000017674d6f 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x00000000176753da 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:29.371525 [ 1808 ] {cc17128e-096f-4387-a138-441030c2ced3} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51184) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_ub767igi_test1.`../tmp_numbers_*.csv`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000017674d6f 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x00000000176753da 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:29.380311 [ 1808 ] {} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000017674d6f 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x00000000176753da 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:30.007175 [ 24374 ] {86a0e31d-7472-4b6c-9d48-fc8f95e01e01} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51194) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_ub767igi_test1.`../*.csv`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000017674d6f 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x00000000176753da 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:30.019403 [ 24374 ] {} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000017674d6f 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x00000000176753da 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:30.621670 [ 24374 ] {dbb1047a-4029-4d01-bbd8-a51ea919d48f} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51212) (comment: 02722_database_filesystem.sh) (query 2, line 3) (in query: SELECT COUNT(*) FROM "../02722_database_filesystem_test_ub767igi_we1N/tmp.csv";), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000017674d6f 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x00000000176753da 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:30.627034 [ 24374 ] {} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000017674d6f 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x00000000176753da 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:31.182329 [ 1867 ] {321813e6-f497-430a-b0a6-259ba7d53716} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51224) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_ub767igi_test1.`../../../../../../tmp.csv`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000017674d6f 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x00000000176753da 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:31.190547 [ 1867 ] {} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000017674d6f 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x00000000176753da 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000017675dfe 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cd91a 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d3fa2 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x0000000017efa596 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a99e11 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abaa33 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:31.982022 [ 24374 ] {2c0edfa8-3719-412e-b0a2-32e9f3f6f1c4} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51248) (comment: 02722_database_filesystem.sh) (query 2, line 3) (in query: CREATE DATABASE test_ub767igi_test2 ENGINE = Filesystem('/tmp');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000017674042 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x00000000176787a4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000017676f42 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000176706bf 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000001766ff09 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188aec6f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:19:31.993936 [ 24374 ] {} TCPHandler: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000017674042 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x00000000176787a4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000017676f42 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000176706bf 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000001766ff09 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188aec6f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:19:32.744140 [ 24374 ] {0a60bf43-b8e5-4a0d-8be8-d237ba162ebb} executeQuery: Code: 36. DB::Exception: Path does not exist: /var/lib/clickhouse/user_files/relative_unknown_dir. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51266) (comment: 02722_database_filesystem.sh) (query 2, line 3) (in query: CREATE DATABASE test_ub767igi_test2 ENGINE = Filesystem('relative_unknown_dir');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:61: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000017673f76 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x00000000176787a4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000017676f42 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000176706bf 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000001766ff09 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188aec6f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:19:32.753658 [ 24374 ] {} TCPHandler: Code: 36. DB::Exception: Path does not exist: /var/lib/clickhouse/user_files/relative_unknown_dir. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:61: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000017673f76 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x00000000176787a4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000017676f42 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000176706bf 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000001766ff09 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188aec6f 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:19:33.378464 [ 16819 ] {f2ebfe7a-456c-437d-96c9-bb39789f7d67} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_ub767igi_test1.tmp2.csv' in scope SELECT COUNT(*) FROM test_ub767igi_test1.`tmp2.csv`. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51280) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_ub767igi_test1.`tmp2.csv`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:19:33.383745 [ 16819 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_ub767igi_test1.tmp2.csv' in scope SELECT COUNT(*) FROM test_ub767igi_test1.`tmp2.csv`. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:19:40.167876 [ 830 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.28 06:19:43.627471 [ 1851 ] {5d17ee69-1c31-4480-b4df-68f4383359a5} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt64(inf). (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40558) (comment: 01581_to_int_inf_nan.sql) (query 1, line 1) (in query: SELECT toInt64(inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::NameToInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001627a885 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d704c 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f6a67 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f6000 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:43.630202 [ 1851 ] {} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt64(inf). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::NameToInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001627a885 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d704c 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f6a67 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f6000 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:43.810851 [ 1851 ] {3f4ddc1d-ae82-48b0-8d2e-a51ec6c1acd7} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt128(inf). (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40558) (comment: 01581_to_int_inf_nan.sql) (query 2, line 2) (in query: SELECT toInt128(inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber>, DB::detail::NameToInt128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000016285000 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d8506 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f8487 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f7a20 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:43.812165 [ 1851 ] {} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt128(inf). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber>, DB::detail::NameToInt128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000016285000 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d8506 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f8487 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f7a20 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:43.965182 [ 1851 ] {1c471f1b-5e5c-4c7b-8c6f-63b0bf770e56} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt256(inf). (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40558) (comment: 01581_to_int_inf_nan.sql) (query 3, line 3) (in query: SELECT toInt256(inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber>, DB::detail::NameToInt256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001628eec3 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d9a06 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f9ea7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f9440 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:43.966370 [ 1851 ] {} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt256(inf). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber>, DB::detail::NameToInt256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001628eec3 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d9a06 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f9ea7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f9440 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:43.974248 [ 1851 ] {a9c5b848-f89c-4e77-8c36-6b476f22851c} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt64(nan). (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40558) (comment: 01581_to_int_inf_nan.sql) (query 4, line 4) (in query: SELECT toInt64(nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::NameToInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001627a885 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d704c 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f6a67 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f6000 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:43.975262 [ 1851 ] {} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt64(nan). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::NameToInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001627a885 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d704c 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f6a67 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f6000 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:43.982406 [ 1851 ] {81d16cc2-5306-49b7-8684-74b76e8608b8} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt128(nan). (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40558) (comment: 01581_to_int_inf_nan.sql) (query 5, line 5) (in query: SELECT toInt128(nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber>, DB::detail::NameToInt128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000016285000 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d8506 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f8487 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f7a20 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:43.983561 [ 1851 ] {} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt128(nan). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber>, DB::detail::NameToInt128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000016285000 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d8506 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f8487 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f7a20 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:43.990582 [ 1851 ] {e2b03560-48af-4dfc-8b63-b76c68fddd8e} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt256(nan). (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40558) (comment: 01581_to_int_inf_nan.sql) (query 6, line 6) (in query: SELECT toInt256(nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber>, DB::detail::NameToInt256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001628eec3 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d9a06 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f9ea7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f9440 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:43.992035 [ 1851 ] {} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toInt256(nan). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber>, DB::detail::NameToInt256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001628eec3 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d9a06 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f9ea7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToInt256, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f9440 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:44.158566 [ 1851 ] {5f38daa2-799e-4e0a-a124-d2b149fa19ea} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt64(inf). (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40558) (comment: 01581_to_int_inf_nan.sql) (query 7, line 7) (in query: SELECT toUInt64(inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001623e789 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cf2ec 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:44.159697 [ 1851 ] {} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt64(inf). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001623e789 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cf2ec 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:44.307690 [ 1851 ] {56f23507-8867-4edb-b1be-eb24fe2ec3b4} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt256(inf). (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40558) (comment: 01581_to_int_inf_nan.sql) (query 8, line 8) (in query: SELECT toUInt256(inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber>, DB::detail::NameToUInt256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000162533c3 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d1cac 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f01e7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ef780 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:44.308829 [ 1851 ] {} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt256(inf). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber>, DB::detail::NameToUInt256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000162533c3 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d1cac 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f01e7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ef780 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:44.315727 [ 1851 ] {cc1f5e3b-f34d-400d-8713-4f4285de63a1} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt64(nan). (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40558) (comment: 01581_to_int_inf_nan.sql) (query 9, line 9) (in query: SELECT toUInt64(nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001623e789 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cf2ec 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:44.316593 [ 1851 ] {} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt64(nan). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001623e789 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cf2ec 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:44.322266 [ 1851 ] {8d4ebdc4-7355-491f-b0e1-2726f1b338dc} executeQuery: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt256(nan). (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40558) (comment: 01581_to_int_inf_nan.sql) (query 10, line 10) (in query: SELECT toUInt256(nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber>, DB::detail::NameToUInt256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000162533c3 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d1cac 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f01e7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ef780 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:44.323537 [ 1851 ] {} TCPHandler: Code: 70. DB::Exception: Unexpected inf or nan to integer conversion: In scope SELECT toUInt256(nan). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./src/Functions/FunctionsConversion.h:1843: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber>, DB::detail::NameToUInt256, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000162533c3 5. ./src/Functions/FunctionsConversion.h:2467: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161d1cac 6. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161f01e7 7. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToUInt256, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ef780 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 2025.07.28 06:19:50.016166 [ 36292 ] {2df5cb01-97d0-4c8e-a986-cd8d9bf71b36} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33940) (comment: 03221_insert_timeout_overflow_mode.sh) (query 1, line 1) (in query: insert into null_t format Native), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:88: DB::throwOnExecutionStatus(DB::PipelineExecutor::ExecutionStatus) @ 0x000000001bd2b19c 5. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:115: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000001bd2b4a1 6. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:120: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000001bd2b50c 7. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb163 8. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:19:50.239198 [ 36292 ] {2df5cb01-97d0-4c8e-a986-cd8d9bf71b36} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 32. DB::Exception: Attempt to read after eof. (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x0000000010c5ad6f 5. ./src/IO/VarInt.h:78: DB::TCPHandler::receivePacketsExpectData(DB::QueryState&) @ 0x000000001bbf5ae7 6. ./build_docker/./src/Server/TCPHandler.cpp:1032: DB::TCPHandler::skipData(DB::QueryState&) @ 0x000000001bbecd07 7. ./build_docker/./src/Server/TCPHandler.cpp:831: DB::TCPHandler::runImpl() @ 0x000000001bbdaf12 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:19:50.239837 [ 36292 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:88: DB::throwOnExecutionStatus(DB::PipelineExecutor::ExecutionStatus) @ 0x000000001bd2b19c 5. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:115: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000001bd2b4a1 6. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:120: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000001bd2b50c 7. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb163 8. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:19:50.351006 [ 1855 ] {fa327930-bfd8-4394-ac5a-899b4e3ce5cf} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33956) (comment: 03221_insert_timeout_overflow_mode.sh) (query 1, line 1) (in query: select sleep(0.1) from system.numbers settings max_block_size = 1 format Native), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000001bc0554f 3. ./build_docker/./src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001bbfc176 4. ./build_docker/./src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebcbe 5. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:50.352643 [ 1855 ] {fa327930-bfd8-4394-ac5a-899b4e3ce5cf} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33956). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d883af 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2558: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000001bbe8f95 7. ./build_docker/./src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x000000001bbdaef1 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:19:50.353238 [ 1855 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000001bc0554f 3. ./build_docker/./src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001bbfc176 4. ./build_docker/./src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebcbe 5. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:19:51.805692 [ 36283 ] {afc4a27c-be2f-4c6c-aa44-a4a245ec0965} executeQuery: Code: 36. DB::Exception: No such attribute 'value': In scope SELECT dictGet('02183_flat_dictionary', 'value', 0). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34142) (comment: 02183_dictionary_no_attributes.sql) (query 8, line 19) (in query: SELECT dictGet('02183_flat_dictionary', 'value', 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:176: DB::DictionaryStructure::getAttribute(String const&) const @ 0x0000000015f1148e 5. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000089b7b1b 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:19:51.811463 [ 36283 ] {} TCPHandler: Code: 36. DB::Exception: No such attribute 'value': In scope SELECT dictGet('02183_flat_dictionary', 'value', 0). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:176: DB::DictionaryStructure::getAttribute(String const&) const @ 0x0000000015f1148e 5. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000089b7b1b 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:19:55.048013 [ 36310 ] {538c1434-9573-45db-bd1a-c73417f6a108} executeQuery: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types: While executing Remote. (TYPE_MISMATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34520) (comment: 02517_wrong_total_structure_crash.sql) (query 5, line 15) (in query: SELECT field1 FROM alias10__fuzz_13 WHERE arrayEnumerateDense(NULL, tuple('0.2147483646'), NULL) GROUP BY field1, arrayEnumerateDense(('0.02', '0.1', '0'), NULL) WITH TOTALS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::detail::FunctionCast::createArrayWrapper(std::shared_ptr const&, DB::DataTypeArray const&) const @ 0x0000000015fe23b8 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fe1112 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fc7a8d 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5ed8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1802d 10. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000018dd3013 11. ./build_docker/./src/Interpreters/castColumn.cpp:44: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000018dd2393 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:356: DB::adaptBlockStructure(DB::Block const&, DB::Block const&) @ 0x00000000173e5cb5 13. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:686: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x00000000173e29bb 14. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:577: DB::RemoteQueryExecutor::readAsync() @ 0x00000000173e44f5 15. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:182: DB::RemoteSource::tryGenerate() @ 0x000000001c1e3ede 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 17. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:134: DB::RemoteSource::work() @ 0x000000001c1e3b2d 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:19:55.052401 [ 1857 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:52610, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:19:55.052765 [ 1857 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:52610, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:19:55.056349 [ 36310 ] {} TCPHandler: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types: While executing Remote. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::detail::FunctionCast::createArrayWrapper(std::shared_ptr const&, DB::DataTypeArray const&) const @ 0x0000000015fe23b8 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fe1112 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fc7a8d 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5ed8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1802d 10. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000018dd3013 11. ./build_docker/./src/Interpreters/castColumn.cpp:44: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000018dd2393 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:356: DB::adaptBlockStructure(DB::Block const&, DB::Block const&) @ 0x00000000173e5cb5 13. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:686: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x00000000173e29bb 14. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:577: DB::RemoteQueryExecutor::readAsync() @ 0x00000000173e44f5 15. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:182: DB::RemoteSource::tryGenerate() @ 0x000000001c1e3ede 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 17. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:134: DB::RemoteSource::work() @ 0x000000001c1e3b2d 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:55.152487 [ 36310 ] {c7079eeb-cc63-4b2a-a1e0-1c2a27c70d7d} executeQuery: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types: While executing Remote. (TYPE_MISMATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34520) (comment: 02517_wrong_total_structure_crash.sql) (query 9, line 21) (in query: SELECT x FROM distributed GROUP BY x WITH TOTALS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::detail::FunctionCast::createArrayWrapper(std::shared_ptr const&, DB::DataTypeArray const&) const @ 0x0000000015fe23b8 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fe1112 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fc7a8d 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5ed8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1802d 10. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000018dd3013 11. ./build_docker/./src/Interpreters/castColumn.cpp:44: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000018dd2393 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:356: DB::adaptBlockStructure(DB::Block const&, DB::Block const&) @ 0x00000000173e5cb5 13. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:686: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x00000000173e29bb 14. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:577: DB::RemoteQueryExecutor::readAsync() @ 0x00000000173e44f5 15. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:182: DB::RemoteSource::tryGenerate() @ 0x000000001c1e3ede 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 17. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:134: DB::RemoteSource::work() @ 0x000000001c1e3b2d 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:19:55.153702 [ 36328 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:34586, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:19:55.153904 [ 36328 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:34586, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:19:55.154656 [ 36310 ] {} TCPHandler: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types: While executing Remote. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::detail::FunctionCast::createArrayWrapper(std::shared_ptr const&, DB::DataTypeArray const&) const @ 0x0000000015fe23b8 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fe1112 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fc7a8d 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5ed8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 9. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1802d 10. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000018dd3013 11. ./build_docker/./src/Interpreters/castColumn.cpp:44: DB::castColumn(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000018dd2393 12. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:356: DB::adaptBlockStructure(DB::Block const&, DB::Block const&) @ 0x00000000173e5cb5 13. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:686: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x00000000173e29bb 14. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:577: DB::RemoteQueryExecutor::readAsync() @ 0x00000000173e44f5 15. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:182: DB::RemoteSource::tryGenerate() @ 0x000000001c1e3ede 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 17. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:134: DB::RemoteSource::work() @ 0x000000001c1e3b2d 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:55.610636 [ 36324 ] {70a730ab-5c28-4118-88da-b620622e617b} executeQuery: Code: 59. DB::Exception: Illegal type UInt16 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34574) (comment: 02559_multiple_read_steps_in_prewhere.sql) (query 13, line 26) (in query: SELECT cast(id1 as UInt16) AS cond1 FROM test_02559 PREWHERE cond1 LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x000000001a97a1f9 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x000000001b547082 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x000000001b545549 7. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x000000001b56a277 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56992e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x000000001b563e14 10. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000001c3f29e1 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x000000001b57235a 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000001c3d523e 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:19:55.612199 [ 36324 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type UInt16 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Columns/FilterDescription.cpp:98: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x000000001a97a1f9 5. ./src/Storages/MergeTree/MergeTreeRangeReader.h:95: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x000000001b547082 6. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1435: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) const @ 0x000000001b545549 7. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:110: DB::MergeTreeReadersChain::executePrewhereActions(DB::MergeTreeRangeReader&, DB::MergeTreeRangeReader::ReadResult&, DB::Block const&, bool) @ 0x000000001b56a277 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:75: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56992e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x000000001b563e14 10. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000001c3f29e1 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x000000001b57235a 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000001c3d523e 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:19:55.989072 [ 36331 ] {ad9fe471-5efc-461e-ac99-9eab23322139} executeQuery: Code: 16. DB::Exception: StorageJoin doesn't contain column : In scope SELECT joinGet('t1', '', number) FROM numbers(2). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34644) (comment: 01141_join_get_negative.sql) (query 5, line 7) (in query: SELECT joinGet('t1', '', number) FROM numbers(2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:991: DB::HashJoin::joinGetCheckAndGetReturnType(std::vector, std::allocator>> const&, String const&, bool) const @ 0x0000000018f8069b 5. ./build_docker/./src/Storages/StorageJoin.cpp:354: DB::StorageJoin::joinGetCheckAndGetReturnType(std::vector, std::allocator>> const&, String const&, bool) const @ 0x000000001ab13b61 6. DB::(anonymous namespace)::JoinGetOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x00000000087fb4f6 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190d2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:55.990911 [ 36331 ] {} TCPHandler: Code: 16. DB::Exception: StorageJoin doesn't contain column : In scope SELECT joinGet('t1', '', number) FROM numbers(2). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:991: DB::HashJoin::joinGetCheckAndGetReturnType(std::vector, std::allocator>> const&, String const&, bool) const @ 0x0000000018f8069b 5. ./build_docker/./src/Storages/StorageJoin.cpp:354: DB::StorageJoin::joinGetCheckAndGetReturnType(std::vector, std::allocator>> const&, String const&, bool) const @ 0x000000001ab13b61 6. DB::(anonymous namespace)::JoinGetOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x00000000087fb4f6 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190d2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:19:56.135508 [ 36331 ] {4d8f995f-1194-4236-8010-6eeea047f6e9} executeQuery: Code: 264. DB::Exception: joinGet only supports StorageJoin of type Left Any. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34644) (comment: 01141_join_get_negative.sql) (query 6, line 8) (in query: SELECT joinGet('t2', 's', number) FROM numbers(2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1005: DB::HashJoin::joinGet(DB::Block const&, DB::Block const&) const @ 0x0000000018f81130 5. ./build_docker/./src/Storages/StorageJoin.cpp:360: DB::StorageJoin::joinGet(DB::Block const&, DB::Block const&, std::shared_ptr) const @ 0x000000001ab13c49 6. DB::(anonymous namespace)::ExecutableFunctionJoinGet::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087ffedb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 16. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:19:56.136693 [ 36331 ] {} TCPHandler: Code: 264. DB::Exception: joinGet only supports StorageJoin of type Left Any. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1005: DB::HashJoin::joinGet(DB::Block const&, DB::Block const&) const @ 0x0000000018f81130 5. ./build_docker/./src/Storages/StorageJoin.cpp:360: DB::StorageJoin::joinGet(DB::Block const&, DB::Block const&, std::shared_ptr) const @ 0x000000001ab13c49 6. DB::(anonymous namespace)::ExecutableFunctionJoinGet::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087ffedb 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 16. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:19:57.084517 [ 36331 ] {547358a7-4abd-4b45-a473-16332e9bd977} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 15 digits were read: '123456789123451'e-1. Expected to read decimal with scale 5 and precision 18: In scope SELECT CAST('12345678912345.1', 'Decimal(10, 5)'). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34750) (comment: 01327_decimal_cut_extra_digits_after_point.sql) (query 11, line 13) (in query: -- But it's just Decimal64, so there is the limit. SELECT CAST('12345678912345.1' AS Decimal(10, 5));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x00000000174aa23c 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000174a7b44 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x00000000175364a4 6. COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::FunctionCastName, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000161051c4 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator()>>>(T const&) const @ 0x00000000160f4f4f 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x00000000160f0d3c 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000160f0a4a 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:19:57.086378 [ 36331 ] {} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 15 digits were read: '123456789123451'e-1. Expected to read decimal with scale 5 and precision 18: In scope SELECT CAST('12345678912345.1', 'Decimal(10, 5)'). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x00000000174aa23c 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x00000000174a7b44 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x00000000175364a4 6. COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::FunctionCastName, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000161051c4 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator()>>>(T const&) const @ 0x00000000160f4f4f 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x00000000160f0d3c 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x00000000160f0a4a 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008802b44 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 2025.07.28 06:19:57.583406 [ 36333 ] {69a58689-1c8e-49ca-88a2-441a38d90fb4} AsynchronousInsertQueue: Setting 'async_insert_busy_timeout_min_ms'=500 is greater than 'async_insert_busy_timeout_max_ms'=100. Ignoring 'async_insert_busy_timeout_min_ms' 2025.07.28 06:19:57.794424 [ 36333 ] {592565b0-4fe4-4a9a-a33a-dbd99eace6aa} executeQuery: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_increase_rate' must be greater than zero. (INVALID_SETTING_VALUE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42530) (comment: 02968_adaptive_async_insert_timeout.sql) (query 7, line 35) (in query: INSERT INTO async_insert_mt_test SETTINGS async_insert=1, wait_for_async_insert=1, async_insert_busy_timeout_increase_rate=-1.0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:610: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000001811e81d 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:424: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000001811bfd3 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:409: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000001811b9b5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e14418 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:19:57.796031 [ 36333 ] {} TCPHandler: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_increase_rate' must be greater than zero. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:610: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000001811e81d 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:424: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000001811bfd3 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:409: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000001811b9b5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e14418 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:19:57.875923 [ 36333 ] {e69f9527-4678-48a2-bad4-432aae09fc72} executeQuery: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_decrease_rate' must be greater than zero. (INVALID_SETTING_VALUE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42530) (comment: 02968_adaptive_async_insert_timeout.sql) (query 8, line 43) (in query: INSERT INTO async_insert_mt_test SETTINGS async_insert=1, wait_for_async_insert=1, async_insert_busy_timeout_decrease_rate=-1.0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:613: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000001811e88f 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:424: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000001811bfd3 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:409: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000001811b9b5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e14418 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:19:57.877250 [ 36333 ] {} TCPHandler: Code: 471. DB::Exception: Setting 'async_insert_busy_timeout_decrease_rate' must be greater than zero. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:613: DB::AsynchronousInsertQueue::validateSettings(DB::Settings const&, std::shared_ptr) @ 0x000000001811e88f 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:424: DB::AsynchronousInsertQueue::pushDataChunk(std::shared_ptr, DB::AsynchronousInsertQueue::DataChunk, std::shared_ptr) @ 0x000000001811bfd3 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:409: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000001811b9b5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e14418 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:19:58.133380 [ 36343 ] {49f5c042-d7ec-4eaf-b131-614ba8faf25e} executeQuery: Code: 60. DB::Exception: Table test_9w0pszzf.async_inserts1 does not exist. Maybe you meant test_9w0pszzf.async_inserts?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35828) (comment: 02015_async_inserts_6.sh) (in query: INSERT INTO async_inserts1 FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001811a7b5 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000001811b585 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e14418 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:19:58.135210 [ 36343 ] {49f5c042-d7ec-4eaf-b131-614ba8faf25e} DynamicQueryHandler: Code: 60. DB::Exception: Table test_9w0pszzf.async_inserts1 does not exist. Maybe you meant test_9w0pszzf.async_inserts?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001811a7b5 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000001811b585 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e14418 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:19:58.227809 [ 36344 ] {fce0e947-6a07-40a8-83ad-4508ec1d9e88} executeQuery: Code: 73. DB::Exception: Unknown input format BadFormat. (UNKNOWN_FORMAT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35830) (comment: 02015_async_inserts_6.sh) (in query: INSERT INTO async_inserts FORMAT BadFormat ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:356: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001811b289 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000001811b585 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e14418 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:19:58.229582 [ 36344 ] {fce0e947-6a07-40a8-83ad-4508ec1d9e88} DynamicQueryHandler: Code: 73. DB::Exception: Unknown input format BadFormat. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:356: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001811b289 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000001811b585 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e14418 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:19:58.244521 [ 36343 ] {5f1f7a32-4e99-4f17-a6e7-6524be542c9b} executeQuery: Code: 73. DB::Exception: Unknown input format Pretty. (UNKNOWN_FORMAT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35836) (comment: 02015_async_inserts_6.sh) (in query: INSERT INTO async_inserts FORMAT Pretty ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:356: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001811b289 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000001811b585 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e14418 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:19:58.245604 [ 36343 ] {5f1f7a32-4e99-4f17-a6e7-6524be542c9b} DynamicQueryHandler: Code: 73. DB::Exception: Unknown input format Pretty. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:356: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001811b289 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000001811b585 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e14418 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:19:58.335047 [ 36340 ] {864b7442-9c15-414e-8587-55534cc1eac3} executeQuery: Code: 16. DB::Exception: No such column a in table test_9w0pszzf.async_inserts (b49eeb17-3cba-439a-ae53-2e6ea2a3c66d). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35852) (comment: 02015_async_inserts_6.sh) (in query: INSERT INTO async_inserts (id, a) FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x0000000018912dc6 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000018911d6c 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:343: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001811a89a 7. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000001811b585 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e14418 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:19:58.336355 [ 36340 ] {864b7442-9c15-414e-8587-55534cc1eac3} DynamicQueryHandler: Code: 16. DB::Exception: No such column a in table test_9w0pszzf.async_inserts (b49eeb17-3cba-439a-ae53-2e6ea2a3c66d). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x0000000018912dc6 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000018911d6c 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:343: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001811a89a 7. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000001811b585 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e14418 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:19:59.735542 [ 36350 ] {7c7729d9-6f7a-44e6-bba6-57a97b5faee1} executeQuery: Code: 128. DB::Exception: Too large array size (maximum: 1073741824): While executing BinaryRowInputFormat. (TOO_LARGE_ARRAY_SIZE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42766) (comment: 02682_quantiles_too_large_size.sql) (query 1, line 1) (in query: -- This query throw high-level exception instead of low-level "too large size passed to allocator": SELECT * FROM format(RowBinary, 'ik2 String, Sum AggregateFunction(sum, UInt16), A$g AggregateFunction(quantiles(0.4, 0.9), UInt64), GroupArray AggregateFunction(groupArray, String)', '295TMi44400000005942762421546108502 ö z *  ParalcelParsingInputFormat   te Date, I ! STRING  d Tuple(UInt8) vvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvTabSeparatedWithNamesAndTypes d Date, a S)ring, x UInt32, y UInt64, z Float32 29TabSeparatevvvvvvvdRawWithNames a UInt32 26TabSeparatedR,éb UInt32 26TabSeparatedRawWithNthNames vvvvv 1 key U7878 ');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000009480fe0 4. ./src/AggregateFunctions/ReservoirSampler.h:216: ReservoirSampler>::read(DB::ReadBuffer&) @ 0x0000000011850690 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionQuantile.cpp:62: DB::AggregateFunctionQuantile, DB::NameQuantiles, false, double, true, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000011800141 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:47: DB::SerializationAggregateFunction::deserializeBinary(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000017519794 7. ./build_docker/./src/Processors/Formats/Impl/BinaryRowInputFormat.cpp:136: DB::BinaryRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001bde8541 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001bd27481 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013d056ab 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 19. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 2025.07.28 06:19:59.739059 [ 36350 ] {} TCPHandler: Code: 128. DB::Exception: Too large array size (maximum: 1073741824): While executing BinaryRowInputFormat. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x0000000009480fe0 4. ./src/AggregateFunctions/ReservoirSampler.h:216: ReservoirSampler>::read(DB::ReadBuffer&) @ 0x0000000011850690 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionQuantile.cpp:62: DB::AggregateFunctionQuantile, DB::NameQuantiles, false, double, true, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000011800141 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:47: DB::SerializationAggregateFunction::deserializeBinary(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000017519794 7. ./build_docker/./src/Processors/Formats/Impl/BinaryRowInputFormat.cpp:136: DB::BinaryRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001bde8541 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001bd27481 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013d056ab 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 19. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 2025.07.28 06:20:02.980912 [ 36357 ] {90220dc0-7ca4-4369-969c-c81ccf4d1948} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43078) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 1, line 1) (in query: SELECT count(*) FROM distributed_00754;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 2025.07.28 06:20:02.987563 [ 36357 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:03.179967 [ 708 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.28 06:20:03.537649 [ 36356 ] {61ef890f-a5fe-4c95-bbb0-12f7cf11c7be} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43134) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 1, line 1) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 2025.07.28 06:20:03.542217 [ 36356 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:04.780851 [ 36356 ] {ee4341c9-1b4f-4f2d-8846-59cda28d8d27} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43292) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 2 AND b = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 2025.07.28 06:20:04.784061 [ 36356 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:08.593464 [ 1865 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:36662, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:20:08.593925 [ 1865 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:36662, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:20:08.802910 [ 35821 ] {5e1daa5b-afa1-45dd-a31c-3ef561258622} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 27. DB::Exception: Cannot parse input: expected '\t' at end of stream.: (at row 1) : Buffer has gone, cannot extract information about what has been parsed. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000010c325ec 5. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x000000001c03951b 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001bdfcf6a 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 11. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001bf46e17 12. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001bf4509e 13. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bf484f8 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000001bf4669d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000001bf4459d 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000001bf49950 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bf49802 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000001bf47c02 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000001bf46477 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:20:08.804908 [ 36270 ] {5e1daa5b-afa1-45dd-a31c-3ef561258622} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' at end of stream.: (at row 1) : Buffer has gone, cannot extract information about what has been parsed.: While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42008) (comment: 01271_http_code_parse_error.sh) (in query: insert into test (f1, f2) format TSV ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000010c325ec 5. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x000000001c03951b 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001bdfcf6a 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 11. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001bf46e17 12. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001bf4509e 13. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bf484f8 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:20:08.807577 [ 36270 ] {5e1daa5b-afa1-45dd-a31c-3ef561258622} DynamicQueryHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' at end of stream.: (at row 1) : Buffer has gone, cannot extract information about what has been parsed.: While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x0000000010c325ec 5. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x000000001c03951b 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001bdfcf6a 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 11. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001bf46e17 12. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:95: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001bf4509e 13. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bf484f8 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:293: DB::ParallelParsingInputFormat::scheduleParserThreadForUnitWithNumber(unsigned long) @ 0x000000001bf4669d 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:45: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000001bf4459d 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x000000001bf49950 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bf49802 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ParallelParsingInputFormat*, std::shared_ptr>(void (DB::ParallelParsingInputFormat::*&&)(std::shared_ptr), DB::ParallelParsingInputFormat*&&, std::shared_ptr&&) @ 0x000000001bf47c02 5. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:158: DB::ParallelParsingInputFormat::read() @ 0x000000001bf46477 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e9ad 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ba5e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:20:08.850070 [ 1851 ] {} void DB::TCPHandler::runImpl(): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:36690). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d883af 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2558: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000001bbe8f95 7. ./build_docker/./src/Server/TCPHandler.cpp:423: DB::TCPHandler::runImpl() @ 0x000000001bbddd73 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:20:08.850853 [ 1851 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:36690, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000010c558c0 8. ./build_docker/./src/Server/TCPHandler.cpp:1805: DB::TCPHandler::receiveAddendum() @ 0x000000001bbe859f 9. ./build_docker/./src/Server/TCPHandler.cpp:351: DB::TCPHandler::runImpl() @ 0x000000001bbd9197 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:20:08.851278 [ 1851 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:36690, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000010c558c0 8. ./build_docker/./src/Server/TCPHandler.cpp:1805: DB::TCPHandler::receiveAddendum() @ 0x000000001bbe859f 9. ./build_docker/./src/Server/TCPHandler.cpp:351: DB::TCPHandler::runImpl() @ 0x000000001bbd9197 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:20:09.285594 [ 1851 ] {264ac391-df17-4a66-9ebb-b37dea4cc9be} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36714) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b <= 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 2025.07.28 06:20:09.289808 [ 1851 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:09.890440 [ 1859 ] {62e7a411-1e19-49f1-b3e2-c7fd4616b6fb} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36742) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 WHERE c LIKE '%l%';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 2025.07.28 06:20:09.894639 [ 1859 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:10.173285 [ 1865 ] {d4893826-2a15-4366-99fd-311c7afa699f} executeQuery: Code: 36. DB::Exception: Dictionary (`test_dictionary`) not found: while executing 'FUNCTION dictHas('test_dictionary' :: 3, tuple(materialize('Ke\0')) :: 10) -> dictHas('test_dictionary', tuple(materialize('Ke\0'))) UInt8 : 5'. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36740) (comment: 02516_projections_and_context.sql) (query 5, line 5) (in query: SELECT count() FROM test1__fuzz_37 GROUP BY dictHas(NULL, (dictHas(NULL, (('', materialize(NULL)), materialize(NULL))), 'KeyKey')), dictHas('test_dictionary', tuple(materialize('Ke\0'))), tuple(dictHas(NULL, (tuple('Ke\0Ke\0Ke\0Ke\0Ke\0Ke\0\0\0\0Ke\0'), materialize(NULL)))), 'test_dicti\0nary', (('', materialize(NULL)), dictHas(NULL, (dictHas(NULL, tuple(materialize(NULL))), 'KeyKeyKeyKeyKeyKeyKeyKey')), materialize(NULL));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000018843520 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000018843154 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000089b8e86 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089c6928 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:20:10.176049 [ 1865 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`test_dictionary`) not found: while executing 'FUNCTION dictHas('test_dictionary' :: 3, tuple(materialize('Ke\0')) :: 10) -> dictHas('test_dictionary', tuple(materialize('Ke\0'))) UInt8 : 5'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000018843520 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000018843154 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000089b8e86 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089c6928 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:10.196139 [ 1865 ] {673d5a18-f079-42df-bbe5-266edefeb8bb} executeQuery: Code: 36. DB::Exception: Dictionary (`non_existing_dictionary`) not found: while executing 'FUNCTION dictHas('non_existing_dictionary' :: 0, materialize('a') :: 3) -> dictHas('non_existing_dictionary', materialize('a')) UInt8 : 1'. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36740) (comment: 02516_projections_and_context.sql) (query 6, line 6) (in query: SELECT count() FROM test1__fuzz_37 GROUP BY dictHas('non_existing_dictionary', materialize('a'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000018843520 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000018843154 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000089b8e86 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089c6928 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:20:10.197649 [ 1865 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`non_existing_dictionary`) not found: while executing 'FUNCTION dictHas('non_existing_dictionary' :: 0, materialize('a') :: 3) -> dictHas('non_existing_dictionary', materialize('a')) UInt8 : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000018843520 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000018843154 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000089b8e86 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089c6928 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:10.254155 [ 1865 ] {8a2f432a-d5ef-41e5-9c81-51c8aeae1a2e} executeQuery: Code: 36. DB::Exception: Dictionary (`test_dictionary`) not found: while executing 'FUNCTION dictHas('test_dictionary'_String :: 0, tuple(materialize('Ke\0'_String)) :: 1) -> dictHas('test_dictionary'_String, tuple(materialize('Ke\0'_String))) UInt8 : 3'. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36740) (comment: 02516_projections_and_context.sql) (query 8, line 8) (in query: SELECT count() FROM test1__fuzz_37 GROUP BY dictHas(NULL, (dictHas(NULL, (('', materialize(NULL)), materialize(NULL))), 'KeyKey')), dictHas('test_dictionary', tuple(materialize('Ke\0'))), tuple(dictHas(NULL, (tuple('Ke\0Ke\0Ke\0Ke\0Ke\0Ke\0\0\0\0Ke\0'), materialize(NULL)))), 'test_dicti\0nary', (('', materialize(NULL)), dictHas(NULL, (dictHas(NULL, tuple(materialize(NULL))), 'KeyKeyKeyKeyKeyKeyKeyKey')), materialize(NULL));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000018843520 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000018843154 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000089b8e86 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089c6928 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:20:10.255945 [ 1865 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`test_dictionary`) not found: while executing 'FUNCTION dictHas('test_dictionary'_String :: 0, tuple(materialize('Ke\0'_String)) :: 1) -> dictHas('test_dictionary'_String, tuple(materialize('Ke\0'_String))) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000018843520 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000018843154 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000089b8e86 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089c6928 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:10.280403 [ 1865 ] {6bc21a65-d4e6-4c12-8612-ebeb7dcac4ae} executeQuery: Code: 36. DB::Exception: Dictionary (`non_existing_dictionary`) not found: while executing 'FUNCTION dictHas('non_existing_dictionary'_String :: 0, materialize('a'_String) :: 3) -> dictHas('non_existing_dictionary'_String, materialize('a'_String)) UInt8 : 1'. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36740) (comment: 02516_projections_and_context.sql) (query 9, line 9) (in query: SELECT count() FROM test1__fuzz_37 GROUP BY dictHas('non_existing_dictionary', materialize('a'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000018843520 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000018843154 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000089b8e86 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089c6928 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:20:10.281839 [ 1865 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`non_existing_dictionary`) not found: while executing 'FUNCTION dictHas('non_existing_dictionary'_String :: 0, materialize('a'_String) :: 3) -> dictHas('non_existing_dictionary'_String, materialize('a'_String)) UInt8 : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x0000000018843520 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000018843154 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x00000000089b8e86 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000089c6928 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:10.474116 [ 1859 ] {a8936027-513f-4ea4-8768-6c46ca2cbdc3} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36760) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 OR a = 1 AND b = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 2025.07.28 06:20:10.475907 [ 1859 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:10.574808 [ 2054 ] {fac3f426-a5b1-4b80-8c41-4c12063f6836} executeQuery: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt8: In scope SELECT arrayEnumerateUniqRanked(arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]]), materialize(1 AS x) OR toLowCardinality(-9223372036854775808)). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36766) (comment: 03003_arrayEnumerate_crash.sql) (query 1, line 1) (in query: SELECT arrayEnumerateUniqRanked(arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]]), materialize(1 AS x) OR toLowCardinality(-9223372036854775808));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x00000000101cc32c 4. DB::getArraysDepths(std::vector> const&, char const*) @ 0x00000000101cbc79 5. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x00000000101de49d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:20:10.575998 [ 2054 ] {} TCPHandler: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt8: In scope SELECT arrayEnumerateUniqRanked(arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]]), materialize(1 AS x) OR toLowCardinality(-9223372036854775808)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x00000000101cc32c 4. DB::getArraysDepths(std::vector> const&, char const*) @ 0x00000000101cbc79 5. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x00000000101de49d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:20:10.586038 [ 2054 ] {c1079f95-b1a1-4ea7-853e-1dbc80119f89} executeQuery: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt64: In scope SELECT arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]], number) FROM numbers(10). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36766) (comment: 03003_arrayEnumerate_crash.sql) (query 2, line 2) (in query: SELECT arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]], number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x00000000101cc32c 4. DB::getArraysDepths(std::vector> const&, char const*) @ 0x00000000101cbc79 5. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x00000000101de49d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:20:10.587221 [ 2054 ] {} TCPHandler: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt64: In scope SELECT arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]], number) FROM numbers(10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x00000000101cc32c 4. DB::getArraysDepths(std::vector> const&, char const*) @ 0x00000000101cbc79 5. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x00000000101de49d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:20:11.095306 [ 2054 ] {ddbd1ac8-ebe1-4bbc-b5c3-aa51a1efe9d2} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36790) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b = 0 OR a = 2 AND b = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 2025.07.28 06:20:11.098860 [ 2054 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:11.730103 [ 36313 ] {896c4dbc-e8bb-4297-8b95-501a44a218bb} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36804) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (query 2, line 3) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b = 0 OR c LIKE '%l%';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 2025.07.28 06:20:11.738005 [ 36313 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001ba79751 4. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001ba6c009 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000173f37e4 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000173eab80 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000173df677 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000001740c208 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000001740abbf 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000001740a6c0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000017409963 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:18.196536 [ 36349 ] {02366_9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36856) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_9.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:18.263469 [ 36322 ] {8da5e880-dfdf-4dde-a56d-4f09bf09fa51} executeQuery: Code: 252. DB::Exception: Too many parts (10 with average size of 168.00 B) in table 'test_x5tm7vgg.too_many_parts (d31be302-0394-4021-b903-342ba7a4d3a9)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36838) (comment: 01603_insert_select_too_many_parts.sql) (query 8, line 14) (in query: -- exception is thrown if threshold is exceeded on new INSERT. INSERT INTO too_many_parts SELECT * FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x000000001b3ae3ac 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4937: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001b3480f5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000001b7ffc7b 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0471 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afad9 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:20:18.265517 [ 36322 ] {} TCPHandler: Code: 252. DB::Exception: Too many parts (10 with average size of 168.00 B) in table 'test_x5tm7vgg.too_many_parts (d31be302-0394-4021-b903-342ba7a4d3a9)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x000000001b3ae3ac 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4937: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001b3480f5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000001b7ffc7b 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0471 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afad9 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:18.345398 [ 36281 ] {02366_6} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36926) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_6.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:18.730006 [ 36305 ] {db1ce5b1-d427-480f-b7b9-7ef4f3b8c37e} executeQuery: Code: 289. DB::Exception: Replica doesn't have part '20181115_0_0_0' which was successfully written to quorum of other replicas. Send query to another replica or disable 'select_sequential_consistency' setting. (REPLICA_IS_NOT_IN_QUORUM) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36946) (comment: 02377_majority_insert_quorum_zookeeper_long.sql) (query 24, line 43) (in query: SELECT x FROM quorum3 ORDER BY x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5755: DB::StorageReplicatedMergeTree::getMaxAddedBlocks() const @ 0x000000001acff19c 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5834: DB::StorageReplicatedMergeTree::readLocalSequentialConsistencyImpl(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, unsigned long, unsigned long) @ 0x000000001ad001c3 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5786: DB::StorageReplicatedMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001acff895 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa683 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 9. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:20:18.731379 [ 36305 ] {} TCPHandler: Code: 289. DB::Exception: Replica doesn't have part '20181115_0_0_0' which was successfully written to quorum of other replicas. Send query to another replica or disable 'select_sequential_consistency' setting. (REPLICA_IS_NOT_IN_QUORUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5755: DB::StorageReplicatedMergeTree::getMaxAddedBlocks() const @ 0x000000001acff19c 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5834: DB::StorageReplicatedMergeTree::readLocalSequentialConsistencyImpl(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, unsigned long, unsigned long) @ 0x000000001ad001c3 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5786: DB::StorageReplicatedMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001acff895 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000189aa683 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a0d4f 9. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:20:18.814238 [ 36338 ] {02366_3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36858) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_3.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:18.997455 [ 2095 ] {02366_8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36862) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_8.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:19.082156 [ 36271 ] {02366_2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36878) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_2.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:19.160718 [ 36302 ] {02366_1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36944) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_1.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:19.177569 [ 36295 ] {02366_7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36942) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_7.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:19.192815 [ 36280 ] {02366_5} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36916) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_5.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:19.239253 [ 36275 ] {02366_4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36902) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_4.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:19.363842 [ 36274 ] {02366_10} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36886) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_10.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:23.361839 [ 36292 ] {a3ea5345-d453-4ef7-824e-5832f10e9410} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 1.00, current rows: 121.00: While executing EmbeddedRocksDB. (TOO_MANY_ROWS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42566) (comment: 02892_rocksdb_trivial_count.sql) (query 3, line 5) (in query: -- { echoOn } SELECT count() FROM dict SETTINGS optimize_trivial_approximate_count_query = 0, max_rows_to_read = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000173d8103 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd21a90 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:23.364052 [ 36292 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 1.00, current rows: 121.00: While executing EmbeddedRocksDB. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000173d8103 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd21a90 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:23.424071 [ 36279 ] {f6cb930b-8f72-4583-b60f-ed5f25775d4d} executeQuery: Code: 215. DB::Exception: Column mn is not under aggregate function and not in GROUP BY keys. In query SELECT n, number + 5 AS inter FROM (SELECT toFloat32(number % 10) AS n, number, number * 2 AS mn FROM numbers(10) WHERE (number % 3) = 1) GROUP BY n, inter ORDER BY n ASC WITH FILL FROM 0 TO 5.51 STEP 0.5 INTERPOLATE ( inter AS mn * 2 ). (NOT_AN_AGGREGATE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42576) (comment: 03155_analyzer_interpolate.sql) (query 3, line 9) (in query: SELECT n, number+5 AS inter FROM ( -- { serverError NOT_AN_AGGREGATE } SELECT toFloat32(number % 10) AS n, number, number*2 AS mn FROM numbers(10) WHERE number % 3 = 1 ) GROUP BY n, inter ORDER BY n WITH FILL FROM 0 TO 5.51 STEP 0.5 INTERPOLATE (inter AS mn * 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af3da3 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af38c6 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af38c6 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af38c6 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af38c6 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:357: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af31a3 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:20:23.429079 [ 36279 ] {} TCPHandler: Code: 215. DB::Exception: Column mn is not under aggregate function and not in GROUP BY keys. In query SELECT n, number + 5 AS inter FROM (SELECT toFloat32(number % 10) AS n, number, number * 2 AS mn FROM numbers(10) WHERE (number % 3) = 1) GROUP BY n, inter ORDER BY n ASC WITH FILL FROM 0 TO 5.51 STEP 0.5 INTERPOLATE ( inter AS mn * 2 ). (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af3da3 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af38c6 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af38c6 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af38c6 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017af38c6 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:357: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000017af31a3 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8088a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.168891 [ 36305 ] {0e642549-2383-45d1-b782-91b18299ab90} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:36946) (comment: 02377_majority_insert_quorum_zookeeper_long.sql) (query 31, line 54) (in query: INSERT INTO quorum1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000001b766268 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000001b7825a8 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000001b763b7c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001b751338 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000001b76288f 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0891 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afd01 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.197195 [ 36305 ] {} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000001b766268 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000001b7825a8 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000001b763b7c 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001b751338 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000001b76288f 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001c0b0891 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c0b02f7 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000001c0afd01 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001bd2b72e 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001bbeb2e6 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000001bbdaa35 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.507773 [ 36286 ] {8849ec66-e1e7-4e21-bf57-c371af36e06c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42598) (comment: 01553_settings_early_apply.sql) (query 3, line 4) (in query: select * from numbers(100) settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.510481 [ 36286 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.535548 [ 36286 ] {da8cda2a-cdf9-4f36-b1c4-e657ad018773} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42598) (comment: 01553_settings_early_apply.sql) (query 4, line 5) (in query: select * from numbers(100) FORMAT JSON settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.537806 [ 36286 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.562921 [ 36286 ] {1f50de69-c574-4868-9e0e-46a960afef7e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42598) (comment: 01553_settings_early_apply.sql) (query 5, line 6) (in query: select * from numbers(100) FORMAT TSVWithNamesAndTypes settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.564571 [ 36286 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.599225 [ 36286 ] {e066620e-95d4-4b1e-a743-5058cce22c4f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42598) (comment: 01553_settings_early_apply.sql) (query 6, line 7) (in query: select * from numbers(100) FORMAT CSVWithNamesAndTypes settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.601845 [ 36286 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.623400 [ 36286 ] {1e8adf2a-4e6e-4ca9-bdb1-df287c4f590c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42598) (comment: 01553_settings_early_apply.sql) (query 7, line 8) (in query: select * from numbers(100) FORMAT JSONCompactEachRowWithNamesAndTypes settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.630578 [ 36286 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.644492 [ 36286 ] {c66797b7-2ed4-4d67-b3b3-550e5757aa5b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42598) (comment: 01553_settings_early_apply.sql) (query 8, line 9) (in query: select * from numbers(100) FORMAT XML settings max_result_rows = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.647291 [ 36286 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.685254 [ 36286 ] {277fab0e-0939-4e12-b8fc-4cb370c3469c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42598) (comment: 01553_settings_early_apply.sql) (query 10, line 12) (in query: select * from numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:20:24.694965 [ 36286 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000001741124c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000001740fa2c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000001740fcfd 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000001c0ca255 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:26.209647 [ 916 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.28 06:20:27.101458 [ 24379 ] {3ab39044-992f-445a-8d66-64a17aed0663} executeQuery: Code: 57. DB::Exception: Table test_tyymgdw2.table1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42670) (comment: 03305_parallel_with.sql) (query 5, line 12) (in query: CREATE TABLE table1(x Int32) ENGINE=MergeTree order by x PARALLEL WITH CREATE TABLE table2(y Int32) ENGINE=MergeTree order by y;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d01e6 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Interpreters/InterpreterParallelWithQuery.cpp:122: DB::InterpreterParallelWithQuery::executeSubquery(std::shared_ptr, std::shared_ptr) @ 0x0000000018eb90d1 10. ./build_docker/./src/Interpreters/InterpreterParallelWithQuery.cpp:97: void std::__function::__policy_invoker::__call_impl[abi:ne190107], 7ul, std::allocator>> const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000018eb98ad 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013f1b251 12. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000013f1afd2 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013f1aec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:20:27.173831 [ 24379 ] {} TCPHandler: Code: 57. DB::Exception: Table test_tyymgdw2.table1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d01e6 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Interpreters/InterpreterParallelWithQuery.cpp:122: DB::InterpreterParallelWithQuery::executeSubquery(std::shared_ptr, std::shared_ptr) @ 0x0000000018eb90d1 10. ./build_docker/./src/Interpreters/InterpreterParallelWithQuery.cpp:97: void std::__function::__policy_invoker::__call_impl[abi:ne190107], 7ul, std::allocator>> const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000018eb98ad 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013f1b251 12. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000013f1afd2 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000013f1aec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000013f1a6ee 5. ./build_docker/./src/Interpreters/InterpreterParallelWithQuery.cpp:107: DB::InterpreterParallelWithQuery::executeSubqueries(absl::lts_20250127::InlinedVector, 7ul, std::allocator>> const&) @ 0x0000000018eb8af6 6. ./build_docker/./src/Interpreters/InterpreterParallelWithQuery.cpp:60: DB::InterpreterParallelWithQuery::execute() @ 0x0000000018eb8313 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:20:27.705826 [ 36349 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:28.139609 [ 36281 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:28.482806 [ 36271 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:28.604017 [ 36275 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:28.754186 [ 36302 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:28.807081 [ 36338 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:28.856972 [ 36280 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:28.882425 [ 36274 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:28.886908 [ 2095 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:28.917670 [ 36295 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:30.479670 [ 1041 ] {} 0c91c1d0-f7ea-4e76-9937-04c4cdcd8b22::all_1_1_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001c863fe4 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:16: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000001c862af4 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2181: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000001ac79375 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x000000001b61bef7 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000001b6b79e7 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000001b6b5fc9 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:20:30.480490 [ 1041 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0c91c1d0-f7ea-4e76-9937-04c4cdcd8b22::all_1_1_0_2}: Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001c863fe4 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:16: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000001c862af4 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2181: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000001ac79375 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x000000001b61bef7 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000001b6b79e7 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000001b6b5fc9 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:20:30.480950 [ 1036 ] {} 0c91c1d0-f7ea-4e76-9937-04c4cdcd8b22::all_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001c863fe4 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:16: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000001c862af4 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2181: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000001ac79375 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x000000001b61bef7 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000001b6b79e7 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000001b6b5fc9 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:20:30.481478 [ 1036 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0c91c1d0-f7ea-4e76-9937-04c4cdcd8b22::all_0_0_0_2}: Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001c863fe4 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:16: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000001c862af4 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2181: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000001ac79375 7. ./build_docker/./src/Storages/MergeTree/MutateFromLogEntryTask.cpp:241: DB::MutateFromLogEntryTask::finalize(std::function) @ 0x000000001b61bef7 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000001b6b79e7 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000001b6b5fc9 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:20:30.605500 [ 17260 ] {913ae522-f642-4d08-9ba4-eebeffa89b59} ExternalDictionariesLoader: Could not load external dictionary '353e8ef8-e875-46bc-8233-b4d55c86ad5b', next update is scheduled at 2025-07-28 06:20:36: Code: 36. DB::Exception: 353e8ef8-e875-46bc-8233-b4d55c86ad5b: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x000000001442245c 5. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000014422ac7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015f050fb 7. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000188421e1 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000018853ac0 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001884ef74 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x0000000018857c88 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000018857a82 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x0000000018852d11 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x000000001884d590 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000001886a7ab 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x000000001884ad1e 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x0000000018848707 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000188439c6 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x0000000018e54ac6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:20:30.606895 [ 24374 ] {913ae522-f642-4d08-9ba4-eebeffa89b59} executeQuery: Code: 36. DB::Exception: 353e8ef8-e875-46bc-8233-b4d55c86ad5b: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42674) (comment: 02391_hashed_dictionary_shards.sql) (query 36, line 106) (in query: SYSTEM RELOAD DICTIONARY test_dictionary_10_shards_incremental;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x000000001442245c 5. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000014422ac7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015f050fb 7. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000188421e1 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000018853ac0 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001884ef74 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x0000000018857c88 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000018857a82 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:30.608218 [ 24374 ] {} TCPHandler: Code: 36. DB::Exception: 353e8ef8-e875-46bc-8233-b4d55c86ad5b: SHARDS parameter does not supports for updatable source (UPDATE_FIELD). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:89: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x000000001442245c 5. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:127: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000014422ac7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015f050fb 7. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000188421e1 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000018853ac0 9. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001884ef74 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x0000000018857c88 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000018857a82 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x0000000018852d11 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x000000001884d590 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000001886a7ab 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x000000001884ad1e 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x0000000018848707 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000188439c6 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x0000000018e54ac6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.001134 [ 36289 ] {02366_4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52072) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_4.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.032640 [ 36289 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.050545 [ 36285 ] {02366_1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52088) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_1.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.063055 [ 36285 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.174799 [ 36290 ] {02366_7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52096) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_7.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.213658 [ 36290 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.355145 [ 1860 ] {02366_3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52042) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_3.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.376770 [ 1860 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.394443 [ 1855 ] {02366_6} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52028) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_6.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.401185 [ 36294 ] {02366_9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52132) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_9.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.424607 [ 1855 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.425490 [ 36282 ] {02366_5} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52104) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_5.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.432408 [ 36296 ] {02366_10} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52144) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_10.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.437808 [ 36294 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.443085 [ 36282 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.457808 [ 36287 ] {02366_2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52058) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_2.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.461598 [ 36296 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.491703 [ 36287 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.566189 [ 36291 ] {02366_8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52120) (comment: 02366_cancel_write_into_file.sh) (query 1, line 1) (in query: insert into function file('02366_data_8.jsonl') select range(number % 1000) from numbers(100000) settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:35.580966 [ 36291 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:20:39.542950 [ 36306 ] {579d6a1f-5a22-4c4d-a0cd-733d3b345bdd} executeQuery: Code: 36. DB::Exception: Unexpected type Decimal(38, 3) in function 'transform': In scope SELECT transform(-9223372036854775807, [-1], [toDecimal32(1024, 3)]) FROM system.numbers LIMIT 7. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53434) (comment: 02542_transform_new.sql) (query 31, line 33) (in query: SELECT transform(-9223372036854775807, [-1], [toDecimal32(1024, 3)]) FROM system.numbers LIMIT 7;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x000000000ef7e12f 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef36f48 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:20:39.546864 [ 36306 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected type Decimal(38, 3) in function 'transform': In scope SELECT transform(-9223372036854775807, [-1], [toDecimal32(1024, 3)]) FROM system.numbers LIMIT 7. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x000000000ef7e12f 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef36f48 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:20:39.563000 [ 36306 ] {3a0b7faf-b3b8-4abb-a8eb-a5fb59697300} executeQuery: Code: 36. DB::Exception: Unexpected type Decimal(38, 2) in function 'transform': In scope SELECT [NULL, NULL, NULL, NULL], transform(number, [2147483648], [toDecimal32(1, 2)]) AS x FROM numbers(257) WHERE materialize(10). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53434) (comment: 02542_transform_new.sql) (query 32, line 34) (in query: SELECT [NULL, NULL, NULL, NULL], transform(number, [2147483648], [toDecimal32(1, 2)]) AS x FROM numbers(257) WHERE materialize(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x000000000ef7e12f 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef36f48 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:20:39.564893 [ 36306 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected type Decimal(38, 2) in function 'transform': In scope SELECT [NULL, NULL, NULL, NULL], transform(number, [2147483648], [toDecimal32(1, 2)]) AS x FROM numbers(257) WHERE materialize(10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x000000000ef7e12f 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef36f48 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:20:39.575227 [ 36306 ] {90b2f5df-f72c-41c4-8028-98a3899bf36a} executeQuery: Code: 36. DB::Exception: Unexpected type Decimal(38, 2) in function 'transform': In scope SELECT transform(-2147483649, [1], [toDecimal32(1, 2)]) GROUP BY [1] WITH TOTALS. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53434) (comment: 02542_transform_new.sql) (query 33, line 35) (in query: SELECT transform(-2147483649, [1], [toDecimal32(1, 2)]) GROUP BY [1] WITH TOTALS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x000000000ef7e12f 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef36f48 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:20:39.576411 [ 36306 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected type Decimal(38, 2) in function 'transform': In scope SELECT transform(-2147483649, [1], [toDecimal32(1, 2)]) GROUP BY [1] WITH TOTALS. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionTransform::checkAllowedTypeHelper(std::shared_ptr const&) @ 0x000000000ef7e12f 5. DB::(anonymous namespace)::FunctionTransform::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ef36f48 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:20:41.650069 [ 36309 ] {2150c204-ef2a-4082-b411-8957be78432a} executeQuery: Code: 36. DB::Exception: intExp2 must not be called with nan: In scope SELECT intExp2(nan). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53538) (comment: 00536_int_exp_overflow.sql) (query 4, line 4) (in query: SELECT intExp2(nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000c03a419 5. DB::UnaryOperationImpl>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000c039f6f 6. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c030853 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:20:41.651933 [ 36309 ] {} TCPHandler: Code: 36. DB::Exception: intExp2 must not be called with nan: In scope SELECT intExp2(nan). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000c03a419 5. DB::UnaryOperationImpl>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000c039f6f 6. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c030853 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:20:41.851894 [ 36309 ] {f5a0809f-a46b-42c7-b200-1f40f5795de1} executeQuery: Code: 36. DB::Exception: intExp2 must not be called with nan: In scope SELECT intExp10(nan). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53538) (comment: 00536_int_exp_overflow.sql) (query 8, line 9) (in query: SELECT intExp10(nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000c02df3b 5. DB::UnaryOperationImpl>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000c02da8f 6. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c026273 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:20:41.853160 [ 36309 ] {} TCPHandler: Code: 36. DB::Exception: intExp2 must not be called with nan: In scope SELECT intExp10(nan). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::UnaryOperationImpl>::vectorImplAVX2(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000c02df3b 5. DB::UnaryOperationImpl>::vector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000c02da8f 6. DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c026273 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:20:45.061328 [ 1054 ] {} test_4hnrl6jf.r2 (46f335ab-6dee-4c79-95d2-df170e726720): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://c8651378e883:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2Ftest_4hnrl6jf%2Fr%2Freplicas%2Fr1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 133 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.6.10634.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, int&&, String const&, unsigned long&&, String const&) @ 0x0000000010fc21fc 4. ./build_docker/./src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000010fc200e 5. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000010fc1d31 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000013cef022 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000013cef1f4 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000013cefca0 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000013cf2e57 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cec6b9 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000013cf1361 12. DB::ReadBuffer::next() @ 0x0000000008915c7b 13. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000013cee96e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000013ce2eab 15. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x000000001b193806 16. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x000000001ada7861 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aca6d20 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x000000001ac9763c 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000001ac7dfd8 20. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x000000001ada4421 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b725a6a 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x000000001acd1c9b 23. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3935: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001ada5429 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b1e046e 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d5cdf 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2d6a10 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc4c2 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:20:49.230340 [ 904 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.28 06:20:49.337590 [ 36324 ] {b5573262-f709-480f-a05d-e2aa65cfd682} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 128.02 MiB (attempt to allocate chunk of 128.02 MiB bytes), maximum: 95.37 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58014) (comment: 01910_memory_tracking_topk.sql) (query 2, line 6) (in query: SELECT length(topK(5592405)(tuple(number))) FROM numbers(10) GROUP BY number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./src/Common/AllocatorWithMemoryTracking.h:33: AllocatorWithMemoryTracking::Counter, std::default_delete::Counter>>>::allocate(unsigned long) @ 0x000000001354c94e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:305: std::vector::Counter, std::default_delete::Counter>>, AllocatorWithMemoryTracking::Counter, std::default_delete::Counter>>>>::reserve(unsigned long) @ 0x000000001354c7f4 10. ./src/Common/SpaceSaving.h:151: DB::(anonymous namespace)::AggregateFunctionTopKGeneric::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x0000000013491f66 11. ./src/AggregateFunctions/IAggregateFunction.h:448: DB::IAggregateFunctionHelper>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000013493b44 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1338: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x00000000183b63f9 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1191: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000001857f047 14. ./build_docker/./src/Interpreters/Aggregator.cpp:995: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000001857d238 15. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x00000000184728a0 16. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x00000000183b34c8 17. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b953b 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 19. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:20:49.358676 [ 36324 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 128.02 MiB (attempt to allocate chunk of 128.02 MiB bytes), maximum: 95.37 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x0000000010bb84ce 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb67d2 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000010bb61e7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x0000000010ae32be 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x0000000010ae345f 8. ./src/Common/AllocatorWithMemoryTracking.h:33: AllocatorWithMemoryTracking::Counter, std::default_delete::Counter>>>::allocate(unsigned long) @ 0x000000001354c94e 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:305: std::vector::Counter, std::default_delete::Counter>>, AllocatorWithMemoryTracking::Counter, std::default_delete::Counter>>>>::reserve(unsigned long) @ 0x000000001354c7f4 10. ./src/Common/SpaceSaving.h:151: DB::(anonymous namespace)::AggregateFunctionTopKGeneric::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x0000000013491f66 11. ./src/AggregateFunctions/IAggregateFunction.h:448: DB::IAggregateFunctionHelper>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000013493b44 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1338: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x00000000183b63f9 13. ./build_docker/./src/Interpreters/Aggregator.cpp:1191: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000001857f047 14. ./build_docker/./src/Interpreters/Aggregator.cpp:995: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000001857d238 15. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x00000000184728a0 16. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x00000000183b34c8 17. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000183b953b 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001c08d048 19. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000001c0881d3 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:20:50.723094 [ 36332 ] {113f4f80-44ff-49fc-b644-7b5fe7d8b2ab} DynamicQueryHandler: Code: 271. DB::Exception: Cannot decompress, the number of elements in the compressed data (65) is not equal to the expected number of elements in the decompressed data (1). (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000009677026 4. ./build_docker/./src/Compression/CompressionCodecT64.cpp:589: DB::CompressionCodecT64::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x000000001ce3d0e1 5. ./build_docker/./src/Compression/ICompressionCodec.cpp:119: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x000000001ce79d41 6. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:329: DB::CompressedReadBufferBase::decompress(DB::BufferBase::Buffer&, unsigned long, unsigned long) @ 0x000000001ce0ef13 7. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:24: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x000000001ce0cbd6 8. DB::ReadBuffer::next() @ 0x0000000008915c7b 9. ./build_docker/./src/IO/ReadBuffer.cpp:34: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x0000000010c2adbb 10. DB::ReadBuffer::next() @ 0x0000000008915c7b 11. ./src/IO/ReadBuffer.h:96: DB::ConcatReadBuffer::nextImpl() @ 0x000000001812de37 12. DB::ReadBuffer::next() @ 0x0000000008915c7b 13. ./src/IO/ReadBuffer.h:81: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1a97f 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:09.445262 [ 36356 ] {61a5159f-4668-49d5-8002-21bfac2b9ead} executeQuery: Code: 207. DB::Exception: JOIN ALL RIGHT JOIN ... USING (key1, key2) ambiguous identifier 'b'. In scope SELECT b FROM t ALL RIGHT JOIN tj USING (key1, key2) ORDER BY key1 ASC. (AMBIGUOUS_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 32, line 41) (in query: SELECT b FROM t ALL RIGHT JOIN tj USING (key1, key2) ORDER BY key1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000017ac59cc 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1079: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f029b3 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1376: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f015d9 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1438: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000017f0618c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9921d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:21:09.453086 [ 36356 ] {} TCPHandler: Code: 207. DB::Exception: JOIN ALL RIGHT JOIN ... USING (key1, key2) ambiguous identifier 'b'. In scope SELECT b FROM t ALL RIGHT JOIN tj USING (key1, key2) ORDER BY key1 ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000017ac59cc 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1079: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f029b3 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1376: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f015d9 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1438: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000017f0618c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9921d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:21:09.476640 [ 36356 ] {3e21202a-8958-402c-88ed-25d7f2f850cf} executeQuery: Code: 207. DB::Exception: JOIN ALL RIGHT JOIN ... USING (key1, key2) ambiguous identifier 'x'. In scope SELECT x FROM t ALL RIGHT JOIN tj USING (key1, key2) ORDER BY key1 ASC. (AMBIGUOUS_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 33, line 42) (in query: SELECT x FROM t ALL RIGHT JOIN tj USING (key1, key2) ORDER BY key1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000017ac59cc 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1079: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f029b3 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1376: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f015d9 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1438: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000017f0618c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9921d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:21:09.477729 [ 36356 ] {} TCPHandler: Code: 207. DB::Exception: JOIN ALL RIGHT JOIN ... USING (key1, key2) ambiguous identifier 'x'. In scope SELECT x FROM t ALL RIGHT JOIN tj USING (key1, key2) ORDER BY key1 ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000017ac59cc 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1079: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f029b3 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1376: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f015d9 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1438: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000017f0618c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9921d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:21:09.497131 [ 36344 ] {c15db50d-dd2a-4625-875e-8ba430a273b3} executeQuery: Code: 70. DB::Exception: Conversion from AggregateFunction(argMax, String, UInt64) to AggregateFunction(argMax, Enum8('' = -1, 'Male' = 1, 'Female' = 2), UInt64) is not supported: While processing _CAST(arrayReduce('argMaxState', ['cast(-1, \'Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2)'], [toUInt64(0)]) AS t_tmp_alter8435113016500990121, 'AggregateFunction(argMax, Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2), UInt64)') AS t: default expression and column type are incompatible. (CANNOT_CONVERT_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43842) (comment: 01258_wrong_cast_filimonov.sql) (query 1, line 1) (in query: CREATE TABLE x (`id` UInt64, `t` AggregateFunction(argMax, Enum8('' = -1, 'Male' = 1, 'Female' = 2), UInt64) DEFAULT arrayReduce('argMaxState', ['cast(-1, \'Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2)'], [toUInt64(0)])) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 10464, min_bytes_for_wide_part = 877171561, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 514521177, compact_parts_max_bytes_to_buffer = 92762898, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 2291032, merge_max_block_size = 17045, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 6418185113, index_granularity_bytes = 8866976, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 97, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 52055, primary_key_compress_block_size = 31179, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x0000000015fe532f 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fe1192 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fc7a8d 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5ed8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000179c7f86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000179c74ff 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000018357bbc 12. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000183688de 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000001835a076 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018358954 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001834bf4d 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001831d06c 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000183312c3 18. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x00000000183318b9 19. ./build_docker/./src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x000000001a9fb9c5 20. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000001a9fbebf 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4eca 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:21:09.514055 [ 36344 ] {} TCPHandler: Code: 70. DB::Exception: Conversion from AggregateFunction(argMax, String, UInt64) to AggregateFunction(argMax, Enum8('' = -1, 'Male' = 1, 'Female' = 2), UInt64) is not supported: While processing _CAST(arrayReduce('argMaxState', ['cast(-1, \'Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2)'], [toUInt64(0)]) AS t_tmp_alter8435113016500990121, 'AggregateFunction(argMax, Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2), UInt64)') AS t: default expression and column type are incompatible. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x0000000015fe532f 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fe1192 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000015fc7a8d 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000015fc5ed8 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000015fc5541 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000179c7f86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000179c74ff 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000018357bbc 12. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000183688de 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x000000001835a076 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018358954 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001834bf4d 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x000000001831d06c 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000183312c3 18. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x00000000183318b9 19. ./build_docker/./src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x000000001a9fb9c5 20. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000001a9fbebf 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000188b4eca 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b7056 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:21:09.686893 [ 36356 ] {dd47c93f-f9c1-44d3-9a0e-e9296f921a5f} executeQuery: Code: 207. DB::Exception: JOIN ALL RIGHT JOIN ... ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ambiguous identifier 'key1'. In scope SELECT key1 FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ORDER BY t.key1 ASC. (AMBIGUOUS_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 39, line 50) (in query: SELECT key1 FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 ORDER BY t.key1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000017ac59cc 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1079: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f029b3 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1376: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f015d9 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1438: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000017f0618c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9921d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:21:09.689702 [ 36356 ] {} TCPHandler: Code: 207. DB::Exception: JOIN ALL RIGHT JOIN ... ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ambiguous identifier 'key1'. In scope SELECT key1 FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ORDER BY t.key1 ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000017ac59cc 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1079: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f029b3 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1376: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f015d9 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1438: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000017f0618c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9921d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.084629 [ 36356 ] {e164dfd2-b09e-4026-844e-e145861a3ad5} executeQuery: Code: 207. DB::Exception: JOIN ALL RIGHT JOIN ... ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ambiguous identifier 'b'. In scope SELECT b FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ORDER BY t.key1 ASC. (AMBIGUOUS_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 49, line 60) (in query: SELECT b FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 ORDER BY t.key1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000017ac59cc 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1079: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f029b3 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1376: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f015d9 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1438: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000017f0618c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9921d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.087904 [ 36356 ] {} TCPHandler: Code: 207. DB::Exception: JOIN ALL RIGHT JOIN ... ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ambiguous identifier 'b'. In scope SELECT b FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ORDER BY t.key1 ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000017ac59cc 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1079: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f029b3 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1376: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f015d9 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1438: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000017f0618c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9921d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.105802 [ 36356 ] {94122e27-6ed2-4a3b-a5e3-2f8c2e0aed60} executeQuery: Code: 207. DB::Exception: JOIN ALL RIGHT JOIN ... ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ambiguous identifier 'x'. In scope SELECT x FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ORDER BY t.key1 ASC. (AMBIGUOUS_IDENTIFIER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 50, line 61) (in query: SELECT x FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 ORDER BY t.key1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000017ac59cc 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1079: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f029b3 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1376: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f015d9 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1438: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000017f0618c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9921d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.107759 [ 36356 ] {} TCPHandler: Code: 207. DB::Exception: JOIN ALL RIGHT JOIN ... ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ambiguous identifier 'x'. In scope SELECT x FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) ORDER BY t.key1 ASC. (AMBIGUOUS_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000017ac59cc 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1079: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f029b3 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1376: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017f015d9 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1438: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000017f0618c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1497: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000017a9921d 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a877c8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 29. __tsan_thread_start_func @ 0x0000000008756428 30. ? @ 0x00007fecd6763ac3 31. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.356248 [ 36356 ] {414738cd-1f51-4ab9-a061-923a73e8a75d} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column 'plus(__table2.key2, 1_UInt8)' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 55, line 68) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 + 1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.358078 [ 36356 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column 'plus(__table2.key2, 1_UInt8)' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.558843 [ 36356 ] {d9a934d7-d099-4bcd-8794-ef186855df7d} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '_CAST(1_UInt8, 'UInt8'_String)' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 57, line 71) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 AND 1 == 1 ORDER BY ALL SETTINGS query_plan_use_new_logical_join_step = 0 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1428: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b77d4 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.561030 [ 36356 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '_CAST(1_UInt8, 'UInt8'_String)' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1428: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b77d4 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.625422 [ 36356 ] {163560b5-f0ad-423c-b20b-99a11dcb7aba} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 59, line 73) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 AND 1 == 2 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.626760 [ 36356 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.649361 [ 36356 ] {79529264-5a2b-4ba8-ba03-5db0c22118f7} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column 'equals(__table2.a, 20_UInt8)' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 60, line 75) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 AND tj.a == 20 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.650796 [ 36356 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column 'equals(__table2.a, 20_UInt8)' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.710169 [ 36356 ] {97666329-f7e5-4346-a673-7f00e4c981b6} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 62, line 78) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 AND 1 != 1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.711963 [ 36356 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.738842 [ 36356 ] {0321f33c-406b-4b3c-aba5-2fb3eb7fe8a9} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 63, line 79) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 AND NULL ORDER BY ALL SETTINGS query_plan_use_new_logical_join_step = 0 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1428: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b77d4 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.740417 [ 36356 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1428: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b77d4 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:10.929098 [ 36356 ] {12da9605-071d-4ed4-9e27-467918faee8f} executeQuery: Code: 43. DB::Exception: Illegal type (String) of 3 argument of function and: In scope SELECT * FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) AND 'aaa'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 65, line 82) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 AND 'aaa' FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x00000000087f794c 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000015f8d021 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5152: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017ac0245 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc538 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:21:10.930586 [ 36356 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (String) of 3 argument of function and: In scope SELECT * FROM t ALL RIGHT JOIN tj ON (t.key1 = tj.key1) AND (t.key2 = tj.key2) AND 'aaa'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x00000000087f794c 4. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000015f8d021 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5152: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017ac0245 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc538 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:21:11.019535 [ 36356 ] {06215897-e84c-4886-b50a-11cb81b187a1} executeQuery: Code: 403. DB::Exception: Wrong type String of JOIN expression 'aaa'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 66, line 83) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON 'aaa' FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Planner/PlannerJoinsLogical.cpp:487: DB::buildJoinStepLogical(DB::Block const&, DB::Block const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000189e7b10 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2061: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b118b 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:21:11.023257 [ 36356 ] {} TCPHandler: Code: 403. DB::Exception: Wrong type String of JOIN expression 'aaa'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Planner/PlannerJoinsLogical.cpp:487: DB::buildJoinStepLogical(DB::Block const&, DB::Block const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000189e7b10 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2061: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b118b 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:21:11.046675 [ 36356 ] {7afdb7ef-fff7-47ff-92e1-744a6b1bd182} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '1_UInt8' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 67, line 85) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON t.key1 == tj.key1 AND t.key2 == tj.key2 AND 1 ORDER BY ALL SETTINGS query_plan_use_new_logical_join_step = 0 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1428: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b77d4 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:11.048438 [ 36356 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '1_UInt8' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1428: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b77d4 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000189b36ad 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2310: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000189a1dd2 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000018984bf3 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:11.107940 [ 36356 ] {0876e52a-01b9-497f-8f4c-7945e02ba142} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 69, line 87) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON 0 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:11.109724 [ 36356 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:11.124393 [ 36356 ] {b3eb7fab-afdb-4937-95b7-c5c9e33c95a0} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43820) (comment: 02495_analyzer_storage_join.sql) (query 70, line 88) (in query: SELECT * FROM t ALL RIGHT JOIN tj ON 1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:11.125678 [ 36356 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key1, key2], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x00000000189dfe66 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000189de835 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000001c349302 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000001c4883a0 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001c47b414 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001c36d918 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001897c4bd 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001897c110 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:11.372177 [ 36344 ] {7cab3120-f9b9-41bc-96bb-8547939337bf} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'size' to function 'arrayResize'. Expected: Number, got: Nullable(UInt8): In scope SELECT arrayResize([1, 2, 3], toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43894) (comment: 00557_array_resize.sql) (query 15, line 18) (in query: -- Second argument cannot be Nullable select arrayResize([1, 2, 3], toNullable(3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. ./build_docker/./src/Functions/array/arrayResize.cpp:36: DB::FunctionArrayResize::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017f269b2 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:21:11.374302 [ 36344 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'size' to function 'arrayResize'. Expected: Number, got: Nullable(UInt8): In scope SELECT arrayResize([1, 2, 3], toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. ./build_docker/./src/Functions/array/arrayResize.cpp:36: DB::FunctionArrayResize::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017f269b2 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:21:11.385097 [ 36344 ] {744a768c-3407-49b7-a4b5-5cbf3d40c4f0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'size' to function 'arrayResize'. Expected: Number, got: Nullable(UInt8): In scope SELECT arrayResize(materialize([1]), toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43894) (comment: 00557_array_resize.sql) (query 16, line 20) (in query: SELECT arrayResize(materialize([1]), toNullable(3)) -- { serverError ILLEGAL_TYPE_OF_ARGUMENT } ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. ./build_docker/./src/Functions/array/arrayResize.cpp:36: DB::FunctionArrayResize::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017f269b2 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:21:11.387058 [ 36344 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'size' to function 'arrayResize'. Expected: Number, got: Nullable(UInt8): In scope SELECT arrayResize(materialize([1]), toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x0000000015f321fc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000015f2fa10 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000015f2f2fe 6. ./build_docker/./src/Functions/array/arrayResize.cpp:36: DB::FunctionArrayResize::getReturnTypeImpl(std::vector> const&) const @ 0x0000000017f269b2 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 2025.07.28 06:21:12.312447 [ 779 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.28 06:21:12.809733 [ 36270 ] {60c7fb08-952a-430e-aee8-01afb734e09c} executeQuery: Code: 48. DB::Exception: Alter of type 'ADD_COLUMN' is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43940) (comment: 01461_alter_table_function.sql) (query 10, line 17) (in query: ALTER TABLE table_from_numbers ADD COLUMN col UInt8;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x000000001684c306 4. ./build_docker/./src/Storages/IStorage.cpp:243: DB::IStorage::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001aa2313c 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:21:12.811484 [ 36270 ] {} TCPHandler: Code: 48. DB::Exception: Alter of type 'ADD_COLUMN' is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x000000001684c306 4. ./build_docker/./src/Storages/IStorage.cpp:243: DB::IStorage::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001aa2313c 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:21:12.850574 [ 1029 ] {} f98d41e5-787d-4256-a118-a5783511c08f::all_0_4_12_5 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001c863fe4 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:16: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000001c862af4 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2181: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000001ac79375 7. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:369: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x000000001b286a3b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000001b6b79e7 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000001b6b5fc9 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:12.851745 [ 1029 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f98d41e5-787d-4256-a118-a5783511c08f::all_0_4_12_5}: Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001c863fe4 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:16: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000001c862af4 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2181: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000001ac79375 7. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:369: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x000000001b286a3b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000001b6b79e7 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000001b6b5fc9 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:15.257131 [ 778 ] {} test_7bkmg9gy.table_with_unsuccessful_commits (f98d41e5-787d-4256-a118-a5783511c08f): The local set of parts of table test_7bkmg9gy.table_with_unsuccessful_commits (f98d41e5-787d-4256-a118-a5783511c08f) doesn't look like the set of parts in ZooKeeper: 30.00 rows of 350.00 total rows in filesystem are suspicious. There are 1 uncovered unexpected parts with 30 rows (1 of them is not just-written with 30 rows), 0 missing parts (with 0 blocks), 0 covered unexpected parts (with 0 rows). 2025.07.28 06:21:15.357545 [ 1034 ] {} f98d41e5-787d-4256-a118-a5783511c08f::all_0_4_12_5 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001c863fe4 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:16: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000001c862af4 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2181: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000001ac79375 7. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:369: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x000000001b286a3b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000001b6b79e7 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000001b6b5fc9 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:15.358519 [ 1034 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f98d41e5-787d-4256-a118-a5783511c08f::all_0_4_12_5}: Code: 999. Coordination::Exception: Fault injected (before part commit). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000001c863fe4 5. ./build_docker/./src/Common/ZooKeeper/IKeeper.cpp:16: Coordination::SimpleFaultInjection::SimpleFaultInjection(double, double, String const&) @ 0x000000001c862af4 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2181: DB::StorageReplicatedMergeTree::checkPartChecksumsAndCommit(DB::MergeTreeData::Transaction&, std::shared_ptr const&, std::optional, bool) @ 0x000000001ac79375 7. ./build_docker/./src/Storages/MergeTree/MergeFromLogEntryTask.cpp:369: DB::MergeFromLogEntryTask::finalize(std::function) @ 0x000000001b286a3b 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:233: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000001b6b79e7 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000001b6b5fc9 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.671922 [ 36322 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.693209 [ 36322 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.710466 [ 36322 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.728720 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.754378 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.775076 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.791425 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.806436 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.822725 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.838658 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.858417 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.880944 [ 36329 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.897250 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.915544 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.933324 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.950249 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.967116 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:18.985244 [ 36329 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.002816 [ 36329 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.021337 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.041561 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.126677 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.145063 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.167831 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.184101 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.199914 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.219482 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.240750 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.263574 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.282721 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.308649 [ 36329 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.328479 [ 36322 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.348560 [ 36322 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.365616 [ 36322 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.387434 [ 36322 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.409826 [ 36322 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.438154 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.461946 [ 36329 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.483889 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.505453 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.527199 [ 36329 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.545409 [ 36329 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.565014 [ 36329 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.581483 [ 36329 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.597372 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.616030 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.642157 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.674424 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.695427 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.720350 [ 36329 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.741836 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.761012 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.779890 [ 36329 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.805817 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.831909 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.852571 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.878616 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.901864 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.923365 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.946859 [ 36311 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.976007 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:19.994872 [ 36311 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.020308 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.039467 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.064359 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.088828 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.111323 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.130012 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.145564 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.167383 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.185275 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.202607 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.223916 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.243171 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.260906 [ 36325 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.280815 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.300147 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.319631 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.337761 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.359105 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.377968 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.397296 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.418746 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.438261 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.460644 [ 36311 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.478988 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.497259 [ 36311 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.518949 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.536847 [ 36311 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.556195 [ 36311 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.576390 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.595159 [ 36311 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.614413 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.636519 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.653681 [ 36311 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.674965 [ 36277 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.693801 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.712888 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.731771 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.757646 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.785548 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.809721 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.836023 [ 24373 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.863695 [ 36279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.887045 [ 36279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.903579 [ 36279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.922538 [ 36277 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.941900 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.958025 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.979827 [ 36279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:20.998381 [ 36279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.027330 [ 36279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.069203 [ 36276 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.093672 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.120079 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.148587 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.170056 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.191070 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.207719 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.223871 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.238860 [ 36279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.256806 [ 36279 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.275237 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.291230 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.309720 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.332848 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.348583 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.366081 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.387027 [ 36273 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.406234 [ 36276 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.421651 [ 36276 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.437142 [ 36273 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.455642 [ 36273 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.476718 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.497189 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.513251 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.527521 [ 36276 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.545374 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.562304 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.575212 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.595103 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.613251 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.631819 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.652035 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.666923 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.683426 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.701475 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.718677 [ 1867 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.746782 [ 36305 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.761147 [ 36305 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:21.781867 [ 36320 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:21:31.438137 [ 24374 ] {2fa03d68-5790-4b65-a1d9-14d0805068a9} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT clamp(number, number - 1, number + 1) FROM numbers(3). (NO_COMMON_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45994) (comment: 03036_clamp.sql) (query 13, line 13) (in query: select clamp(number, number-1, number+1) from numbers(3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dfec5c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000174fcb40 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000174fc390 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000174ffaf7 7. DB::FunctionClamp::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0e7182 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 9. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:21:31.441026 [ 24374 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT clamp(number, number - 1, number + 1) FROM numbers(3). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000dfec5c6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000174fcb40 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000174fc390 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000174ffaf7 7. DB::FunctionClamp::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a0e7182 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 9. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:21:31.589642 [ 24374 ] {49e9fafd-f8f2-40be-aaaf-f91a04ee8677} executeQuery: Code: 36. DB::Exception: The minimum value cannot be greater than the maximum value for function clamp: In scope SELECT clamp(1, 3, 2). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45994) (comment: 03036_clamp.sql) (query 14, line 14) (in query: select clamp(1, 3, 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionClamp::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a0e6ff6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:21:31.591229 [ 24374 ] {} TCPHandler: Code: 36. DB::Exception: The minimum value cannot be greater than the maximum value for function clamp: In scope SELECT clamp(1, 3, 2). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionClamp::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a0e6ff6 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14495 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 2025.07.28 06:21:31.729357 [ 24374 ] {8f434517-7411-4b93-8c6e-674fe8bd5afa} executeQuery: Code: 36. DB::Exception: The minimum value cannot be greater than the maximum value for function clamp: while executing 'FUNCTION clamp(1_UInt8 :: 2, arrayElement(__table1.data, 1_UInt8) :: 1, arrayElement(__table1.data, 2_UInt8) :: 5) -> clamp(1_UInt8, arrayElement(__table1.data, 1_UInt8), arrayElement(__table1.data, 2_UInt8)) UInt8 : 3'. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45994) (comment: 03036_clamp.sql) (query 15, line 15) (in query: select clamp(1, data[1], data[2])from (select arrayJoin([[1, 2], [2,3], [3,2], [4, 4]]) as data);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionClamp::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a0e6ff6 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:21:31.731938 [ 24374 ] {} TCPHandler: Code: 36. DB::Exception: The minimum value cannot be greater than the maximum value for function clamp: while executing 'FUNCTION clamp(1_UInt8 :: 2, arrayElement(__table1.data, 1_UInt8) :: 1, arrayElement(__table1.data, 2_UInt8) :: 5) -> clamp(1_UInt8, arrayElement(__table1.data, 1_UInt8), arrayElement(__table1.data, 2_UInt8)) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionClamp::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a0e6ff6 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:21:32.902051 [ 36355 ] {299a0803-0feb-461d-bbfc-65ac25be35a6} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nothing, should be a number: In scope SELECT arrayAUCPR([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46050) (comment: 03272_arrayAUCPR.sql) (query 42, line 52) (in query: -- general negative tests select arrayAUCPR([], []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fb18 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:32.908284 [ 36355 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nothing, should be a number: In scope SELECT arrayAUCPR([], []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fb18 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:32.909381 [ 36298 ] {1f657e3c-c60e-45f6-bc2c-784d3b18f343} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 0, should be 2: In scope SELECT __actionName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46096) (comment: 03035_internal_functions_direct_call.sql) (query 1, line 1) (in query: -- This functions should not be called directly, only for internal use. -- However, we cannot completely forbid it (becasue query can came from another server, for example) -- Check that usage of these functions does not lead to crash or logical error SELECT __actionName();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18abf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:21:32.914053 [ 36298 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 0, should be 2: In scope SELECT __actionName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18abf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:21:32.925597 [ 36298 ] {1499f2c6-a8dd-4224-b38d-6c87071b9858} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName('aaa', 'aaa', 'aaa'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46096) (comment: 03035_internal_functions_direct_call.sql) (query 2, line 6) (in query: SELECT __actionName('aaa', 'aaa', 'aaa');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18abf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:21:32.927673 [ 36298 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName('aaa', 'aaa', 'aaa'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18abf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:21:33.069484 [ 36355 ] {6c944bd8-793b-4c6f-9413-dbcc5f2df4d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 1, should be 2 or 3: In scope SELECT arrayAUCPR([0, 0, 1, 1]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46050) (comment: 03272_arrayAUCPR.sql) (query 43, line 54) (in query: select arrayAUCPR([0, 0, 1, 1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000000f13da2c 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fa56 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.070903 [ 36355 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 1, should be 2 or 3: In scope SELECT arrayAUCPR([0, 0, 1, 1]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000000f13da2c 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fa56 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.116924 [ 36298 ] {52655675-3591-4f44-8c8f-5e1a4dd33e6c} executeQuery: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46096) (comment: 03035_internal_functions_direct_call.sql) (query 3, line 7) (in query: SELECT __actionName('aaa', '') SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:187: DB::(anonymous namespace)::ActionNodeNameHelper::calculateActionNodeName(std::shared_ptr const&) @ 0x0000000017a25c66 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:954: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000017a2a95b 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x0000000017a24917 7. ./build_docker/./src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x0000000017a3c14b 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:380: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x00000000189fa37c 9. ./build_docker/./src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x000000001898631b 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:21:33.120856 [ 36298 ] {} TCPHandler: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:187: DB::(anonymous namespace)::ActionNodeNameHelper::calculateActionNodeName(std::shared_ptr const&) @ 0x0000000017a25c66 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:954: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000017a2a95b 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x0000000017a24917 7. ./build_docker/./src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x0000000017a3c14b 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:380: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x00000000189fa37c 9. ./build_docker/./src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x000000001898631b 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:21:33.135252 [ 36298 ] {237866cd-1252-4e06-b767-1f379d70f02d} executeQuery: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46096) (comment: 03035_internal_functions_direct_call.sql) (query 4, line 8) (in query: SELECT __actionName('aaa', materialize('aaa'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:187: DB::(anonymous namespace)::ActionNodeNameHelper::calculateActionNodeName(std::shared_ptr const&) @ 0x0000000017a25c66 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:954: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000017a2a95b 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x0000000017a24917 7. ./build_docker/./src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x0000000017a3c14b 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:380: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x00000000189fa37c 9. ./build_docker/./src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x000000001898631b 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:21:33.136070 [ 36298 ] {} TCPHandler: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:187: DB::(anonymous namespace)::ActionNodeNameHelper::calculateActionNodeName(std::shared_ptr const&) @ 0x0000000017a25c66 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:954: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000017a2a95b 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x0000000017a24917 7. ./build_docker/./src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x0000000017a3c14b 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:380: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x00000000189fa37c 9. ./build_docker/./src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x000000001898631b 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:21:33.258564 [ 36355 ] {6f16fff4-8907-425c-8faa-eb1d6d5af8b2} executeQuery: Code: 36. DB::Exception: First two arguments for function arrayAUCPR must be Arrays of equal sizes: In scope SELECT arrayAUCPR([0.1, 0.35], [0, 0, 1, 1]). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46050) (comment: 03272_arrayAUCPR.sql) (query 44, line 55) (in query: select arrayAUCPR([0.1, 0.35], [0, 0, 1, 1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f13f15e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:21:33.263244 [ 36355 ] {} TCPHandler: Code: 36. DB::Exception: First two arguments for function arrayAUCPR must be Arrays of equal sizes: In scope SELECT arrayAUCPR([0.1, 0.35], [0, 0, 1, 1]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f13f15e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:21:33.311068 [ 36298 ] {fc3042f1-de9d-4290-bfbb-28c5e94248ae} executeQuery: Code: 44. DB::Exception: Argument at index 0 for function __actionName must be constant. (ILLEGAL_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46096) (comment: 03035_internal_functions_direct_call.sql) (query 5, line 9) (in query: SELECT __actionName(materialize('aaa'), 'aaa');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ac8c7a6 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f13d97 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 13. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 14. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:21:33.312849 [ 36298 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 0 for function __actionName must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ac8c7a6 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f13d97 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f148d4 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000179d249f 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000179d102a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c0b090a 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001c30727b 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000164887a2 13. ./build_docker/./src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001898edc4 14. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000018988519 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001897f960 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001897c6fb 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e15abd 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 26. __tsan_thread_start_func @ 0x0000000008756428 27. ? @ 0x00007fecd6763ac3 28. ? @ 0x00007fecd67f5850 2025.07.28 06:21:33.481558 [ 36355 ] {0cc54493-807b-42bf-8d2c-49350326803e} executeQuery: Code: 43. DB::Exception: Second argument (arr_labels) for function arrayAUCPR is of type Nothing, should be a number or Enum: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46050) (comment: 03272_arrayAUCPR.sql) (query 45, line 56) (in query: select arrayAUCPR([0.1, 0.4, 0.35, 0.8], []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fbda 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.483323 [ 36355 ] {} TCPHandler: Code: 43. DB::Exception: Second argument (arr_labels) for function arrayAUCPR is of type Nothing, should be a number or Enum: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fbda 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.493623 [ 36355 ] {8ef9fbe8-3e94-4390-ae67-f62f0640e093} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 4, should be 2 or 3: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 0, 0], [1, 1, 0, 1]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46050) (comment: 03272_arrayAUCPR.sql) (query 46, line 57) (in query: select arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 0, 0], [1, 1, 0, 1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000000f13da2c 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fa56 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.494670 [ 36355 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 4, should be 2 or 3: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 0, 0], [1, 1, 0, 1]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000000f13da2c 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fa56 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.503405 [ 36355 ] {deb916ad-1c66-4b5f-8ad5-22dafcc2ef66} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type String, should be a number: In scope SELECT arrayAUCPR(['a', 'b', 'c', 'd'], [1, 0, 1, 1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46050) (comment: 03272_arrayAUCPR.sql) (query 47, line 58) (in query: select arrayAUCPR(['a', 'b', 'c', 'd'], [1, 0, 1, 1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fb18 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.505290 [ 36355 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type String, should be a number: In scope SELECT arrayAUCPR(['a', 'b', 'c', 'd'], [1, 0, 1, 1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fb18 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.513879 [ 36355 ] {8124995f-7218-4062-aedd-7e83f510a313} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nullable(Float64), should be a number: In scope SELECT arrayAUCPR([0.1, 0.4, NULL, 0.8], [0, 0, 1, 1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46050) (comment: 03272_arrayAUCPR.sql) (query 48, line 59) (in query: select arrayAUCPR([0.1, 0.4, NULL, 0.8], [0, 0, 1, 1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fb18 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.515022 [ 36355 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nullable(Float64), should be a number: In scope SELECT arrayAUCPR([0.1, 0.4, NULL, 0.8], [0, 0, 1, 1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fb18 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.522960 [ 36355 ] {7f63a65f-f3c8-40bb-9a98-cfd3b836ffb1} executeQuery: Code: 43. DB::Exception: Second argument (arr_labels) for function arrayAUCPR is of type Nullable(UInt8), should be a number or Enum: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, NULL, 1, 1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46050) (comment: 03272_arrayAUCPR.sql) (query 49, line 60) (in query: select arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, NULL, 1, 1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fbda 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.524278 [ 36355 ] {} TCPHandler: Code: 43. DB::Exception: Second argument (arr_labels) for function arrayAUCPR is of type Nullable(UInt8), should be a number or Enum: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, NULL, 1, 1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fbda 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.571372 [ 36298 ] {a98e7ba3-cb32-44f6-9a8c-9fd3f0fec07a} executeQuery: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly: In scope SELECT concat(__actionName('aaa', toNullable('x')), '1') GROUP BY __actionName('aaa', 'x'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46096) (comment: 03035_internal_functions_direct_call.sql) (query 7, line 12) (in query: SELECT concat(__actionName('aaa', toNullable('x')), '1') GROUP BY __actionName('aaa', 'x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::FunctionActionName::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b9a59d8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:21:33.572677 [ 36298 ] {} TCPHandler: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly: In scope SELECT concat(__actionName('aaa', toNullable('x')), '1') GROUP BY __actionName('aaa', 'x'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. DB::FunctionActionName::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b9a59d8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087e1c04 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa190d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:21:33.682702 [ 36355 ] {b7515ea8-426a-4c71-ac69-f25d6dfaa380} executeQuery: Code: 43. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR is of type Nullable(UInt8), should be integer: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 0, NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46050) (comment: 03272_arrayAUCPR.sql) (query 50, line 62) (in query: -- negative tests for optional argument select arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 0, NULL]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000000f13db6c 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fcb1 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.684948 [ 36355 ] {} TCPHandler: Code: 43. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR is of type Nullable(UInt8), should be integer: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 0, NULL]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000000f13db6c 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fcb1 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.694909 [ 36355 ] {ec7a6fa3-352f-4ab3-b72b-10eb1c555afc} executeQuery: Code: 43. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR is of type String, should be integer: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], ['a', 'b', 'c']). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46050) (comment: 03272_arrayAUCPR.sql) (query 51, line 64) (in query: select arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], ['a', 'b', 'c']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000000f13db6c 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fcb1 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.697636 [ 36355 ] {} TCPHandler: Code: 43. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR is of type String, should be integer: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], ['a', 'b', 'c']). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000000f13db6c 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f13fcb1 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f188e7 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.706009 [ 36298 ] {91d4828d-923e-45f0-bbe6-ff522a7b3e91} executeQuery: Code: 36. DB::Exception: Scalar aaa doesn't exist (internal bug): In scope SELECT __getScalar('aaa'). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46096) (comment: 03035_internal_functions_direct_call.sql) (query 8, line 14) (in query: SELECT __getScalar('aaa');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/Context.cpp:2008: DB::Context::getScalar(String const&) const @ 0x000000001819fbba 5. DB::(anonymous namespace)::FunctionGetScalar::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac9268e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:21:33.707611 [ 36298 ] {} TCPHandler: Code: 36. DB::Exception: Scalar aaa doesn't exist (internal bug): In scope SELECT __getScalar('aaa'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/Context.cpp:2008: DB::Context::getScalar(String const&) const @ 0x000000001819fbba 5. DB::(anonymous namespace)::FunctionGetScalar::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac9268e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:21:33.713614 [ 36298 ] {45846f5d-57d7-4252-b2f7-645890cf1fb5} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 0, should be 1: In scope SELECT __getScalar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46096) (comment: 03035_internal_functions_direct_call.sql) (query 9, line 15) (in query: SELECT __getScalar();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:21:33.714839 [ 36298 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 0, should be 1: In scope SELECT __getScalar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:21:33.839665 [ 36355 ] {725a43c9-4fb7-4268-b8d0-e1d91f3a0bd2} executeQuery: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must contain Arrays of size 3: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 1, 0, 0]). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46050) (comment: 03272_arrayAUCPR.sql) (query 52, line 65) (in query: select arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 1, 0, 0]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000000f138eec 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f13f227 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:21:33.840786 [ 36355 ] {} TCPHandler: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must contain Arrays of size 3: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 1, 0, 0]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000000f138eec 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f13f227 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:21:33.864126 [ 36298 ] {23526c0b-a633-4b72-9abb-1be2043c91c2} executeQuery: Code: 43. DB::Exception: Function __getScalar accepts one const string argument: In scope SELECT __getScalar(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46096) (comment: 03035_internal_functions_direct_call.sql) (query 10, line 16) (in query: SELECT __getScalar(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionGetScalar::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac928c9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.865409 [ 36298 ] {} TCPHandler: Code: 43. DB::Exception: Function __getScalar accepts one const string argument: In scope SELECT __getScalar(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionGetScalar::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac928c9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.873374 [ 36298 ] {b802ebd4-25e9-4291-af7f-971d9eaed39c} executeQuery: Code: 43. DB::Exception: Function __getScalar accepts one const string argument: In scope SELECT __getScalar(materialize('1')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46096) (comment: 03035_internal_functions_direct_call.sql) (query 11, line 17) (in query: SELECT __getScalar(materialize('1'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionGetScalar::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac928c9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.874906 [ 36298 ] {} TCPHandler: Code: 43. DB::Exception: Function __getScalar accepts one const string argument: In scope SELECT __getScalar(materialize('1')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. DB::(anonymous namespace)::FunctionGetScalar::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ac928c9 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6728da 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000015f18d7a 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000015f1887d 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f190a5 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 31. __tsan_thread_start_func @ 0x0000000008756428 2025.07.28 06:21:33.923523 [ 36298 ] {2c70d210-e954-47a7-8c9b-98877dbd5e60} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 2, should be 1: In scope SELECT __scalarSubqueryResult(a, a), materialize('1') AS a. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46096) (comment: 03035_internal_functions_direct_call.sql) (query 14, line 21) (in query: SELECT __scalarSubqueryResult(a, a), materialize('1') as a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:21:33.925935 [ 36298 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 2, should be 1: In scope SELECT __scalarSubqueryResult(a, a), materialize('1') AS a. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000149a2ccc 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000015f18489 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000015f19043 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa71e4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:21:33.988950 [ 36355 ] {9735389f-96de-4a9e-821b-3b08da5de8dc} executeQuery: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must not contain negative values: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, -1, 0]). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46050) (comment: 03272_arrayAUCPR.sql) (query 53, line 66) (in query: select arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, -1, 0]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000000f139166 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f13eb89 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:21:33.990070 [ 36355 ] {} TCPHandler: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must not contain negative values: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, -1, 0]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000000f139166 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f13eb89 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087e16e4 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d5dc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f14938 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017aa74b2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000017a870eb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000017a862ad 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017ab9aa2 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7edf2 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:21:34.130812 [ 36355 ] {1a37311b-35d9-4442-bdcb-93029aac9a1e} executeQuery: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must contain Arrays of size 3: while executing 'FUNCTION arrayAUCPR(__table1.x :: 2, __table1.y :: 3, __table1.z :: 4) -> arrayAUCPR(__table1.x, __table1.y, __table1.z) Float64 : 1'. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46050) (comment: 03272_arrayAUCPR.sql) (query 54, line 67) (in query: select arrayAUCPR(x, y, z) from ( select [1] as x, [0] as y, [0, 0, 0, 0, 0, 0] as z UNION ALL select [1] as x, [0] as y, [] as z );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000000f138eec 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f13f227 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:21:34.133877 [ 36355 ] {} TCPHandler: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must contain Arrays of size 3: while executing 'FUNCTION arrayAUCPR(__table1.x :: 2, __table1.y :: 3, __table1.z :: 4) -> arrayAUCPR(__table1.x, __table1.y, __table1.z) Float64 : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000000f138eec 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f13f227 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:21:34.164120 [ 36355 ] {d48f0e70-be89-4e84-817a-f01f7dfa3a40} executeQuery: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must contain Arrays of size 3: while executing 'FUNCTION arrayAUCPR(__table1.x :: 3, __table1.y :: 1, __table1.z :: 2) -> arrayAUCPR(__table1.x, __table1.y, __table1.z) Float64 : 4'. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46050) (comment: 03272_arrayAUCPR.sql) (query 55, line 72) (in query: select arrayAUCPR(x, y, z) from ( select [1] as x, [0] as y, [0, 0] as z UNION ALL select [1] as x, [1] as y, [0, 0, 0, 0] as z );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000000f138eec 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f13f227 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:21:34.166123 [ 36355 ] {} TCPHandler: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must contain Arrays of size 3: while executing 'FUNCTION arrayAUCPR(__table1.x :: 3, __table1.y :: 1, __table1.z :: 2) -> arrayAUCPR(__table1.x, __table1.y, __table1.z) Float64 : 4'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000000f138eec 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f13f227 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:21:35.349598 [ 613 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.28 06:21:58.368195 [ 478 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.28 06:22:21.379321 [ 889 ] {} DNSResolver: Cannot resolve host (localhos), error 0: Host not found. 2025.07.28 06:23:39.448247 [ 36297 ] {8ec4706d-8248-4f6f-838e-f51f0ab7fa87} executeQuery: Code: 497. DB::Exception: test_03312: Not enough privileges. To execute this query, it's necessary to have the grant CHECK ON test_8j3a5a8j.cheque. (ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48402) (comment: 03312_check_table_grant.sh) (query 1, line 2) (in query: CHECK TABLE cheque;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d09340 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d078d1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000016d06c71 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000016cceb63 8. ./src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001819c9bc 9. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:113: DB::InterpreterCheckQuery::execute() @ 0x0000000018e8eb10 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:23:39.449993 [ 36297 ] {} TCPHandler: Code: 497. DB::Exception: test_03312: Not enough privileges. To execute this query, it's necessary to have the grant CHECK ON test_8j3a5a8j.cheque. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d09340 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d078d1 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000016d06c71 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000016cceb63 8. ./src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x000000001819c9bc 9. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:113: DB::InterpreterCheckQuery::execute() @ 0x0000000018e8eb10 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:24:14.382985 [ 36353 ] {} DynamicQueryHandler: Code: 372. DB::Exception: Session test_xpozecg9_10 not found. (SESSION_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/Session.cpp:122: DB::NamedSessionsStorage::acquireSession(std::shared_ptr const&, StrongTypedef, DB::UUIDTag> const&, String const&, std::chrono::duration>, bool) @ 0x0000000018b026d9 5. ./build_docker/./src/Interpreters/Session.cpp:586: DB::Session::makeSessionContext(String const&, std::chrono::duration>, bool) @ 0x0000000018afef5c 6. ./build_docker/./src/Server/HTTPHandler.cpp:247: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1c204 7. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:24:37.180138 [ 42845 ] {df0c0029-b0f8-4dda-94ea-a85995f084e5} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37894) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 ADD COLUMN value1 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:37.180456 [ 42820 ] {f432cfec-a122-47e7-8671-b83fc8adc08b} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37780) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 ADD COLUMN value1 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:37.181222 [ 42832 ] {66f74886-cee7-4e09-b802-c78050a9f53b} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37866) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 ADD COLUMN value4 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:37.181278 [ 42825 ] {b8825412-2faa-4721-b7d3-7735ebc773ce} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37800) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 MODIFY COLUMN value0 String SETTINGS mutations_sync = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:37.187673 [ 42832 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:37.187687 [ 42825 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:37.188149 [ 42845 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:37.188898 [ 42820 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:37.745722 [ 42827 ] {0ea79fab-8034-4a7f-80a5-a6f9d2fd706a} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45218) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 DROP COLUMN value4 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:37.749114 [ 42827 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:37.758614 [ 42843 ] {4583c6de-73a3-43f9-a3bd-cf22bd897515} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value3` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45222) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 DROP COLUMN value3 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:37.761299 [ 42843 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value3` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:37.811412 [ 42845 ] {7c4480d2-7764-49c0-b296-1aa6169b4958} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45224) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:37.813035 [ 42845 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:38.489841 [ 42845 ] {0160b9c1-2e3a-4a78-8c3c-ec373325bbcf} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45296) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 ADD COLUMN value3 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:38.491430 [ 42845 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:38.931488 [ 42845 ] {87f464d6-637a-4de8-ad3f-ad280a3361c5} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45326) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_2 DROP COLUMN value5 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:38.934017 [ 42845 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:39.032835 [ 42843 ] {fdf2afa1-4d4d-4d1f-ab5f-9c57dda83b12} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45366) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 DROP COLUMN value4 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:39.034181 [ 42843 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:39.814694 [ 42853 ] {95c2883f-620f-4140-b151-a6f318641cb2} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45488) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:39.815903 [ 42853 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:40.158281 [ 42853 ] {8121c22e-9b5e-4ec3-86c6-e85c2ff38f0e} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45536) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 DROP COLUMN value5 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:40.159678 [ 42853 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:40.244081 [ 1038 ] {ca8fbc7b-d082-4c65-87bf-8b125bbfa825::all_0_18_5_19} ca8fbc7b-d082-4c65-87bf-8b125bbfa825::all_0_18_5_19 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_18_5_19 from 2 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (99b742f6d9debb701cd3a18e1a7d8901) data.bin: 414563 (1b62b94638b16733aae9ed5643c8abd3) data.cmrk3: 315 (7202759837f84d1d44f5a8c5047faac0) primary.cidx: 96 (a49a4666cab7812fbba868438734cf1e) 2025.07.28 06:24:40.539352 [ 42854 ] {215af97a-fb5d-4ad4-b30f-821b5c93cf13} executeQuery: Code: 15. DB::Exception: Cannot add column `value4`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45600) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_2 ADD COLUMN value4 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:40.541973 [ 42854 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value4`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:41.141621 [ 42867 ] {37948473-5815-4315-b476-fef1e78ac698} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45710) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_2 DROP COLUMN value3 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:41.154858 [ 42867 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:41.181368 [ 42869 ] {603f6b8e-f087-4b7d-9a1a-969a25981c89} executeQuery: Code: 15. DB::Exception: Cannot add column `value4`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45714) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 ADD COLUMN value4 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:41.186721 [ 42869 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value4`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:41.638061 [ 42865 ] {86dc7227-0447-407f-af3a-b246a255c7bc} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45762) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 MODIFY COLUMN value0 String SETTINGS mutations_sync = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:41.640690 [ 42865 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:41.668008 [ 42861 ] {bbba13db-d876-4c26-8d66-c81787d63170} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45764) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 MODIFY COLUMN value0 String SETTINGS mutations_sync = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:41.670305 [ 42861 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:41.758967 [ 42869 ] {2b1ba850-7bff-4cb9-a3e2-29dea67bc2ac} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45774) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 DROP COLUMN value3 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:41.761140 [ 42869 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:42.010374 [ 42865 ] {f2915e5f-3b26-4403-b2aa-29e053d34297} executeQuery: Code: 15. DB::Exception: Cannot add column `value4`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45802) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 ADD COLUMN value4 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:42.012199 [ 42865 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value4`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:42.123159 [ 42872 ] {8601a4dd-232c-421f-93d6-b662e2ff83c5} executeQuery: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45818) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 ADD COLUMN value2 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:42.125479 [ 42872 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:42.633130 [ 42861 ] {44160170-7e19-4f2e-8ce1-5f0b71e762e7} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45864) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 DROP COLUMN value4 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:42.636063 [ 42861 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:42.774281 [ 1033 ] {4d44974e-3f8f-431e-9294-96b19beefbdd::all_0_18_9_22} 4d44974e-3f8f-431e-9294-96b19beefbdd::all_0_18_9_22 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_18_9_22 from 1 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (99b742f6d9debb701cd3a18e1a7d8901) data.bin: 425530 (6d13523a9d40d46fa6cf4335a317f890) data.cmrk3: 335 (4278a9276934f919815e4e6002b8db52) primary.cidx: 101 (ec023bdf9f7d2da52c146af455fe4290) 2025.07.28 06:24:42.959819 [ 42865 ] {69e79af5-4493-4437-bd36-ba8d7fc1c1bf} executeQuery: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45898) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 ADD COLUMN value2 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:42.961905 [ 42865 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:43.240871 [ 42869 ] {2f243816-5192-4bca-bb09-5c8f4667759b} executeQuery: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45928) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_2 ADD COLUMN value2 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:43.243475 [ 42869 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:43.462252 [ 42869 ] {1ab322bb-0923-4182-90fb-1afec9756bc1} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:45972) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 ADD COLUMN value4 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:43.464315 [ 42869 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:43.554293 [ 42875 ] {e4f46888-599c-4a1a-b675-cfac1d26379a} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46004) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 MODIFY COLUMN value0 UInt8 SETTINGS mutations_sync = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:43.560002 [ 42876 ] {4e81e55c-d4e9-4ab1-acbc-f9ac24f268c6} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46020) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 DROP COLUMN value3 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:43.562271 [ 42876 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:43.562796 [ 42875 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:43.782581 [ 1028 ] {0e26c260-828b-400b-82a3-61d7284a9fe0::all_0_18_9_22} 0e26c260-828b-400b-82a3-61d7284a9fe0::all_0_18_9_22 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_18_9_22 from 1 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (99b742f6d9debb701cd3a18e1a7d8901) data.bin: 425530 (6d13523a9d40d46fa6cf4335a317f890) data.cmrk3: 335 (4278a9276934f919815e4e6002b8db52) primary.cidx: 101 (ec023bdf9f7d2da52c146af455fe4290) 2025.07.28 06:24:43.787798 [ 42867 ] {9f4c1043-0b9e-40fd-bb0d-ffcaff29fcc0} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46024) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_2 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:43.789274 [ 42867 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:43.946315 [ 42867 ] {295eeac7-6cf3-4d73-be52-7e90f78abd3a} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46048) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 MODIFY COLUMN value0 UInt8 SETTINGS mutations_sync = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:43.948028 [ 42867 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:44.003127 [ 42869 ] {a665e0bb-bcc0-418a-b533-00741d0e9e2e} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46056) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 DROP COLUMN value5 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:44.006053 [ 42869 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:44.829519 [ 42872 ] {deecf851-f296-4a01-a234-f51c1533a852} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46164) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 ADD COLUMN value4 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:44.831790 [ 42872 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:44.924884 [ 42875 ] {f5312474-1492-4e81-aeed-03f7bcea993c} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46180) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 ADD COLUMN value4 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:44.926475 [ 42875 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:45.174514 [ 42867 ] {1903bc0e-2b82-4fcf-991d-aeecca23f84f} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46188) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:45.176670 [ 42867 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:45.464044 [ 42876 ] {02c713f6-febe-42cf-b06d-d15aea080a85} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46260) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:45.466987 [ 42876 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:45.864960 [ 42811 ] {2c7f0c24-4149-47d4-b207-2afe93f97c6c} executeQuery: Code: 15. DB::Exception: Cannot add column `value3`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46346) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 ADD COLUMN value3 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:45.871525 [ 42811 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value3`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:45.925286 [ 1034 ] {ca8fbc7b-d082-4c65-87bf-8b125bbfa825::all_0_18_12_26} ca8fbc7b-d082-4c65-87bf-8b125bbfa825::all_0_18_12_26 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_18_12_26 from 2 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (99b742f6d9debb701cd3a18e1a7d8901) data.bin: 423501 (06650e71f7a3e745254c70b3f5aebce5) data.cmrk3: 301 (35e334f1ae44086fb16c91d7f285cf5f) primary.cidx: 100 (8c958111084eb2e06733ccb2a3f3bca8) 2025.07.28 06:24:46.027937 [ 36353 ] {a6dc8ab9-0aae-4840-9934-7a58cc3be9bc} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46374) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 MODIFY COLUMN value0 String SETTINGS mutations_sync = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:46.029561 [ 36353 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:46.145060 [ 42874 ] {ad180620-f0d8-4c4b-b87e-11e52c207221} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46384) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 MODIFY COLUMN value0 String SETTINGS mutations_sync = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:46.146800 [ 42874 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:46.201424 [ 1041 ] {0e26c260-828b-400b-82a3-61d7284a9fe0::all_0_18_11_26} 0e26c260-828b-400b-82a3-61d7284a9fe0::all_0_18_11_26 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_18_11_26 from 2 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (99b742f6d9debb701cd3a18e1a7d8901) data.bin: 423501 (06650e71f7a3e745254c70b3f5aebce5) data.cmrk3: 301 (35e334f1ae44086fb16c91d7f285cf5f) primary.cidx: 100 (8c958111084eb2e06733ccb2a3f3bca8) 2025.07.28 06:24:46.268874 [ 42873 ] {65c38e74-d018-478e-8d6f-d65a2d37582a} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46396) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 ADD COLUMN value5 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:46.270328 [ 42873 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:46.441899 [ 42811 ] {dd63ab53-2a0c-464b-8bad-65151a050565} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46410) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 DROP COLUMN value1 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:46.443919 [ 42811 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:46.961812 [ 42874 ] {1b1712a1-ef22-421f-ab1c-8e6355045623} executeQuery: Code: 36. DB::Exception: Cannot drop column value3 because it's affected by mutation with ID '0000000008' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000008'". (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46448) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 DROP COLUMN value3 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String const&, String const&) @ 0x000000001b3bfe54 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8539: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const::$_0::operator()(String const&, String const&, String const&) const @ 0x000000001b38d1e9 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8566: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000001b32d09c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3639: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b326dd5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:24:46.963937 [ 42874 ] {} TCPHandler: Code: 36. DB::Exception: Cannot drop column value3 because it's affected by mutation with ID '0000000008' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000008'". (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String const&, String const&) @ 0x000000001b3bfe54 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8539: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const::$_0::operator()(String const&, String const&, String const&) const @ 0x000000001b38d1e9 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8566: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000001b32d09c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3639: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001b326dd5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc3f 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:24:47.099888 [ 42816 ] {a5e18a5d-ebe6-4bb7-9c7e-6fbb0edc5d06} executeQuery: Code: 15. DB::Exception: Cannot add column `value1`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34490) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 ADD COLUMN value1 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:47.101545 [ 42816 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value1`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:47.668986 [ 42818 ] {b6f6c2c0-04a0-4be7-bd38-53b4552eec53} executeQuery: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34566) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_2 ADD COLUMN value2 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:47.671465 [ 42818 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:48.066051 [ 42818 ] {75b261c8-e402-4102-a29c-74ad2e9fa242} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34602) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 ADD COLUMN value1 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:48.067572 [ 42818 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:48.196345 [ 42820 ] {636aaac2-8423-46b6-9a5b-349baafc1306} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34610) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 MODIFY COLUMN value0 UInt8 SETTINGS mutations_sync = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:48.202283 [ 42820 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:48.212207 [ 42818 ] {f7d48f00-d202-44ad-a590-97a8a721c5c5} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value1` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34624) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_2 DROP COLUMN value1 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:48.213817 [ 42818 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value1` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:48.398162 [ 42820 ] {b68dd02b-af6a-41a2-ad04-001c2932a05e} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34662) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 ADD COLUMN value5 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:48.401096 [ 42820 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:48.603235 [ 36353 ] {04b25cbf-253e-4969-bfdd-1180af313f0c} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34702) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 DROP COLUMN value4 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:48.605038 [ 36353 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:48.982812 [ 36353 ] {7c87b419-0460-4614-af57-9a5f99ae5fc5} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34730) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 DROP COLUMN value5 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:48.985288 [ 36353 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:49.438213 [ 42822 ] {7555ed48-1294-4ce0-92f6-83bfec87da65} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34784) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 DROP COLUMN value5 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:49.439646 [ 42822 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:49.547583 [ 42829 ] {9cfa13d1-3cec-4675-bfb1-7e8f7a194f7e} executeQuery: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34798) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 ADD COLUMN value2 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:49.548716 [ 42829 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:49.744995 [ 42825 ] {9a16e395-4e3b-48d2-8fe2-bc22e521ac03} executeQuery: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34810) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_2 ADD COLUMN value2 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:49.746483 [ 42825 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:50.071698 [ 42822 ] {0c4f15c5-8786-4db2-ba4e-b2fd6be48120} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34882) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 DROP COLUMN value5 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:50.073028 [ 42822 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:50.278651 [ 42822 ] {12e9eba0-6bbf-4379-b13e-a4189613ddc3} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value1` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34912) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_2 DROP COLUMN value1 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:50.285996 [ 42822 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value1` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:50.474335 [ 42822 ] {3a7c7c32-a306-4189-abf8-379f13534fff} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34946) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 MODIFY COLUMN value0 String SETTINGS mutations_sync = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:50.479313 [ 42822 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:50.591263 [ 42843 ] {47a73819-fc9e-4ea4-8405-ed701e6bc604} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34998) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 MODIFY COLUMN value0 String SETTINGS mutations_sync = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:50.591463 [ 1034 ] {ca8fbc7b-d082-4c65-87bf-8b125bbfa825::all_0_18_19_38} ca8fbc7b-d082-4c65-87bf-8b125bbfa825::all_0_18_19_38 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_18_19_38 from 3 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (99b742f6d9debb701cd3a18e1a7d8901) data.bin: 421470 (0cea0cf6a8585310892205b155e8f256) data.cmrk3: 271 (7dbc908082c903f4e70afe97221d4879) primary.cidx: 100 (8c958111084eb2e06733ccb2a3f3bca8) 2025.07.28 06:24:50.593588 [ 42843 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:50.781470 [ 42822 ] {99b561d0-b65c-424e-9728-343e0dfce1de} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35026) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_2 DROP COLUMN value4 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:50.783866 [ 42822 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:50.812205 [ 42825 ] {f177e194-e971-4bc5-9a0f-395ef8995219} executeQuery: Code: 15. DB::Exception: Cannot add column `value3`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35032) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 ADD COLUMN value3 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:50.814277 [ 42825 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value3`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:51.048394 [ 1029 ] {ca8fbc7b-d082-4c65-87bf-8b125bbfa825::all_0_18_20_40} ca8fbc7b-d082-4c65-87bf-8b125bbfa825::all_0_18_20_40 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_18_20_40 from 3 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (99b742f6d9debb701cd3a18e1a7d8901) data.bin: 423501 (06650e71f7a3e745254c70b3f5aebce5) data.cmrk3: 301 (35e334f1ae44086fb16c91d7f285cf5f) primary.cidx: 100 (8c958111084eb2e06733ccb2a3f3bca8) 2025.07.28 06:24:51.575346 [ 42829 ] {4ae20097-d3f1-4c31-86b5-a1cfe6ce5033} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35096) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 ADD COLUMN value5 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:51.577198 [ 42829 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:51.767103 [ 1031 ] {ca8fbc7b-d082-4c65-87bf-8b125bbfa825::all_0_18_22_40} ca8fbc7b-d082-4c65-87bf-8b125bbfa825::all_0_18_22_40 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_18_22_40 from 2 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (99b742f6d9debb701cd3a18e1a7d8901) data.bin: 423501 (06650e71f7a3e745254c70b3f5aebce5) data.cmrk3: 301 (35e334f1ae44086fb16c91d7f285cf5f) primary.cidx: 100 (8c958111084eb2e06733ccb2a3f3bca8) 2025.07.28 06:24:52.333277 [ 42829 ] {2acad440-327e-433f-984f-c43df567352d} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35170) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 MODIFY COLUMN value0 UInt8 SETTINGS mutations_sync = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:52.335168 [ 42829 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:52.365153 [ 42825 ] {2e0004b1-4629-4899-af6c-25dc796759d0} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35202) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_2 ADD COLUMN value1 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:52.367222 [ 42825 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:52.485042 [ 42817 ] {da9e8cda-e157-47a7-bd8e-1ca0c5f00baa} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35206) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 MODIFY COLUMN value0 UInt8 SETTINGS mutations_sync = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:52.488543 [ 42817 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:52.871643 [ 42817 ] {b18eb5ea-7d03-4ad6-8482-dbb6d9d77696} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35268) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_2 ADD COLUMN value5 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:52.873624 [ 42817 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:52.925922 [ 42853 ] {3bedf9b8-f629-4232-8177-d60280e62138} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35296) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_2 DROP COLUMN value4 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:52.928227 [ 42853 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:53.297511 [ 42849 ] {e22cc0b8-41b5-4dd3-a8ea-eed4800231d2} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35324) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 DROP COLUMN value4 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:53.299474 [ 42849 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:53.447217 [ 42854 ] {b028127a-a51c-4f22-ba57-d2cd27239125} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35348) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_2 DROP COLUMN value4 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:53.450330 [ 42854 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:54.091386 [ 42861 ] {666fcade-93e9-46ec-82ef-fab48bd46c6b} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35436) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 ADD COLUMN value2 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:54.097630 [ 42861 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:54.236424 [ 42871 ] {b8ba54c2-51cb-450b-a4c7-ac3711858b62} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35474) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 ADD COLUMN value5 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:54.242435 [ 42871 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:54.424885 [ 42849 ] {ed7b5cdf-13f7-4e99-bba9-3128ee089e45} executeQuery: Code: 15. DB::Exception: Cannot add column `value1`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35498) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 ADD COLUMN value1 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:54.426273 [ 42849 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value1`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:54.616584 [ 42853 ] {16e13a8c-5632-4ef2-bafe-f389f172c9e0} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35536) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_3 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:54.618249 [ 42853 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:54.778011 [ 42861 ] {ebccd212-c7c8-4b13-ad64-bfec6beb7538} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35556) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 DROP COLUMN value3 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:54.780097 [ 42861 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:54.817571 [ 42863 ] {8800c635-7db1-431f-bca9-99c4496fea0c} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35564) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 MODIFY COLUMN value0 String SETTINGS mutations_sync = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:54.819537 [ 42863 ] {} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6684: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001ad12533 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fc83 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:55.002295 [ 42863 ] {65da2ae2-3d8c-4a46-b4f2-e76f4f784287} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35604) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 DROP COLUMN value5 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:55.004473 [ 42863 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9e019e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:24:55.669546 [ 42861 ] {304ed2c9-264e-4a46-a381-d58cbd5ef285} executeQuery: Code: 15. DB::Exception: Cannot add column `value4`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35704) (comment: 03144_parallel_alter_add_drop_column_zookeeper_on_steroids.sh) (query 1, line 1) (in query: ALTER TABLE concurrent_alter_add_drop_steroids_1 ADD COLUMN value4 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:55.671099 [ 42861 ] {} TCPHandler: Code: 15. DB::Exception: Cannot add column `value4`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/AlterCommands.cpp:1435: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001a9df089 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001889fbef 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x000000001889d443 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:24:55.864761 [ 42871 ] {} void DB::TCPHandler::runImpl(): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:35742). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d883af 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2558: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000001bbe8f95 7. ./build_docker/./src/Server/TCPHandler.cpp:423: DB::TCPHandler::runImpl() @ 0x000000001bbddd73 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:24:55.865286 [ 42871 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:35742, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000010c558c0 8. ./build_docker/./src/Server/TCPHandler.cpp:1805: DB::TCPHandler::receiveAddendum() @ 0x000000001bbe859f 9. ./build_docker/./src/Server/TCPHandler.cpp:351: DB::TCPHandler::runImpl() @ 0x000000001bbd9197 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:24:55.865564 [ 42871 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:35742, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x0000000010c558c0 8. ./build_docker/./src/Server/TCPHandler.cpp:1805: DB::TCPHandler::receiveAddendum() @ 0x000000001bbe859f 9. ./build_docker/./src/Server/TCPHandler.cpp:351: DB::TCPHandler::runImpl() @ 0x000000001bbd9197 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:25:39.318010 [ 42863 ] {517ada75-5d10-4736-968b-ece17984322f} executeQuery: Code: 183. DB::Exception: Unexpected expression '*' in filter in WHERE. In query SELECT * WHERE *. (UNEXPECTED_EXPRESSION) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33734) (comment: 03101_analyzer_identifiers_3.sql) (query 17, line 42) (in query: SELECT * WHERE *;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl::type, std::type_identity>&>::type, std::type_identity::type>, String&&, std::basic_string_view>&, String&&) @ 0x0000000017af50ec 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:43: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000017af14b4 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x0000000017af1159 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5773: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8086d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:25:39.319150 [ 42863 ] {} TCPHandler: Code: 183. DB::Exception: Unexpected expression '*' in filter in WHERE. In query SELECT * WHERE *. (UNEXPECTED_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl::type, std::type_identity>&>::type, std::type_identity::type>, String&&, std::basic_string_view>&, String&&) @ 0x0000000017af50ec 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:43: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000017af14b4 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x0000000017af1159 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5773: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a8086d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 24. __tsan_thread_start_func @ 0x0000000008756428 25. ? @ 0x00007fecd6763ac3 26. ? @ 0x00007fecd67f5850 2025.07.28 06:25:42.264146 [ 42863 ] {} DynamicQueryHandler: Code: 511. DB::Exception: There is no role `aaaaaaaaaaa` in user directories. (UNKNOWN_ROLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./src/Access/IAccessStorage.h:118: DB::Context::setCurrentRoles(std::vector> const&, bool) @ 0x000000001819bcb4 7. ./build_docker/./src/Server/HTTPHandler.cpp:399: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1e71b 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:25:42.279822 [ 42863 ] {} DynamicQueryHandler: Code: 511. DB::Exception: There is no role `aaaaaaaaaaa` in user directories. (UNKNOWN_ROLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./src/Access/IAccessStorage.h:118: DB::Context::setCurrentRoles(std::vector> const&, bool) @ 0x000000001819bcb4 7. ./build_docker/./src/Server/HTTPHandler.cpp:399: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1e71b 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:25:42.351526 [ 42863 ] {} DynamicQueryHandler: Code: 512. DB::Exception: Role 03096_role_query_param_role_not_granted should be granted to set as a current. (SET_NON_GRANTED_ROLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/Context.cpp:1673: DB::Context::setCurrentRolesImpl(std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>> const&, bool, bool, std::shared_ptr const&) @ 0x000000001819b723 5. ./build_docker/./src/Interpreters/Context.cpp:1683: DB::Context::setCurrentRoles(std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>> const&, bool) @ 0x000000001819b971 6. ./build_docker/./src/Interpreters/Context.cpp:1701: DB::Context::setCurrentRoles(std::vector> const&, bool) @ 0x000000001819bcc4 7. ./build_docker/./src/Server/HTTPHandler.cpp:399: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1e71b 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:25:42.365567 [ 42863 ] {} DynamicQueryHandler: Code: 512. DB::Exception: Role 03096_role_query_param_role_not_granted should be granted to set as a current. (SET_NON_GRANTED_ROLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/Context.cpp:1673: DB::Context::setCurrentRolesImpl(std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>> const&, bool, bool, std::shared_ptr const&) @ 0x000000001819b723 5. ./build_docker/./src/Interpreters/Context.cpp:1683: DB::Context::setCurrentRoles(std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>> const&, bool) @ 0x000000001819b971 6. ./build_docker/./src/Interpreters/Context.cpp:1701: DB::Context::setCurrentRoles(std::vector> const&, bool) @ 0x000000001819bcc4 7. ./build_docker/./src/Server/HTTPHandler.cpp:399: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1e71b 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:29:33.296201 [ 42863 ] {46f6f418-6cb7-4d92-a1fb-ca22738576dd} Context: An error has occurred while reloading storage policies, storage policies were not applied: volume_priority values must be unique across the policy 2025.07.28 06:29:33.872526 [ 1206 ] {} Context: An error has occurred while reloading storage policies, storage policies were not applied: volume_priority values must cover the range from 1 to N (lowest priority specified) without gaps 2025.07.28 06:29:34.455724 [ 42863 ] {3952c017-1f11-4864-99e4-bcb77fd78762} Context: An error has occurred while reloading storage policies, storage policies were not applied: volume_priority values must cover the range from 1 to N (lowest priority specified) without gaps 2025.07.28 06:29:35.272751 [ 45958 ] {5e9cb26c-8f56-481b-a151-682c9313616e} executeQuery: Code: 36. DB::Exception: Database engine `Atomic` cannot have arguments. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37990) (comment: 02960_validate_database_engines.sql) (query 3, line 8) (in query: -- create database with valid engine but arguments are not allowed. Should fail. CREATE DATABASE test2960_database_engine_args_not_allowed ENGINE = Atomic('foo', 'bar');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFactory.cpp:79: DB::DatabaseFactory::validate(DB::ASTCreateQuery const&) const @ 0x000000001766fced 5. ./build_docker/./src/Databases/DatabaseFactory.cpp:108: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000001766fed4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188aec6f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:29:35.273675 [ 45958 ] {} TCPHandler: Code: 36. DB::Exception: Database engine `Atomic` cannot have arguments. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseFactory.cpp:79: DB::DatabaseFactory::validate(DB::ASTCreateQuery const&) const @ 0x000000001766fced 5. ./build_docker/./src/Databases/DatabaseFactory.cpp:108: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000001766fed4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188aec6f 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:29:35.338386 [ 45958 ] {ab7b6ddf-594a-4934-a37e-a081357fe3c4} executeQuery: Code: 336. DB::Exception: Unknown database engine: Foo. (UNKNOWN_DATABASE_ENGINE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37990) (comment: 02960_validate_database_engines.sql) (query 4, line 11) (in query: -- create database with an invalid engine. Should fail. CREATE DATABASE test2960_invalid_database_engine ENGINE = Foo;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Databases/DatabaseFactory.cpp:103: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000001767033d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188aec6f 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:29:35.339268 [ 45958 ] {} TCPHandler: Code: 336. DB::Exception: Unknown database engine: Foo. (UNKNOWN_DATABASE_ENGINE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Databases/DatabaseFactory.cpp:103: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000001767033d 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188aec6f 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:29:54.971935 [ 45958 ] {b1c24789-f9d8-49be-b903-3a31df2e2a7e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dest_view_set' in scope SELECT * FROM dest_view_set ORDER BY x ASC LIMIT 1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41148) (comment: 02842_truncate_database.sql) (query 34, line 65) (in query: SELECT * FROM dest_view_set ORDER BY x LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:29:54.973203 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dest_view_set' in scope SELECT * FROM dest_view_set ORDER BY x ASC LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:29:54.981399 [ 45958 ] {f57acf6a-b7fe-485e-bd98-ef5ee6ee2801} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dest_view_memory' in scope SELECT * FROM dest_view_memory ORDER BY x ASC LIMIT 1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41148) (comment: 02842_truncate_database.sql) (query 35, line 66) (in query: SELECT * FROM dest_view_memory ORDER BY x LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:29:54.982408 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dest_view_memory' in scope SELECT * FROM dest_view_memory ORDER BY x ASC LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:29:54.990501 [ 45958 ] {e42f4138-c179-40c5-8bb3-a05be141305f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dest_view_log' in scope SELECT * FROM dest_view_log ORDER BY x ASC LIMIT 1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41148) (comment: 02842_truncate_database.sql) (query 36, line 67) (in query: SELECT * FROM dest_view_log ORDER BY x LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:29:54.991251 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dest_view_log' in scope SELECT * FROM dest_view_log ORDER BY x ASC LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:29:54.998198 [ 45958 ] {196ded55-651c-4f00-924e-bf34180f4e6e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dest_view_tiny_log' in scope SELECT * FROM dest_view_tiny_log ORDER BY x ASC LIMIT 1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41148) (comment: 02842_truncate_database.sql) (query 37, line 68) (in query: SELECT * FROM dest_view_tiny_log ORDER BY x LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:29:54.998966 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dest_view_tiny_log' in scope SELECT * FROM dest_view_tiny_log ORDER BY x ASC LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:29:55.006816 [ 45958 ] {a1c8b2c1-75ec-4b4d-9317-17a74d643eb1} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dest_view_stripe_log' in scope SELECT * FROM dest_view_stripe_log ORDER BY x ASC LIMIT 1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41148) (comment: 02842_truncate_database.sql) (query 38, line 69) (in query: SELECT * FROM dest_view_stripe_log ORDER BY x LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:29:55.007824 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dest_view_stripe_log' in scope SELECT * FROM dest_view_stripe_log ORDER BY x ASC LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:29:55.016710 [ 45958 ] {130dd26c-5b5b-4f50-857a-04dcd185f869} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dest_view_merge_tree' in scope SELECT * FROM dest_view_merge_tree ORDER BY x ASC LIMIT 1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41148) (comment: 02842_truncate_database.sql) (query 39, line 70) (in query: SELECT * FROM dest_view_merge_tree ORDER BY x LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:29:55.017640 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dest_view_merge_tree' in scope SELECT * FROM dest_view_merge_tree ORDER BY x ASC LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:29:55.059745 [ 45958 ] {8e358191-ff9b-47ac-909e-3276a43b537b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'dest_dictionary' in scope SELECT * FROM dest_dictionary. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41148) (comment: 02842_truncate_database.sql) (query 41, line 72) (in query: SELECT * FROM dest_dictionary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:29:55.060502 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'dest_dictionary' in scope SELECT * FROM dest_dictionary. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:29:59.861877 [ 45958 ] {} TCPHandler: TCPHandler: Code: 700. DB::Exception: User 504fcf3b-438f-f207-50c9-a2c8501f4ba9 has overflown session count 1. (USER_SESSION_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x00000000089ee886 4. ./build_docker/./src/Interpreters/SessionTracker.cpp:40: DB::SessionTracker::trackSession(StrongTypedef, DB::UUIDTag> const&, DB::SessionInfo const&, unsigned long) @ 0x0000000018b1526a 5. ./build_docker/./src/Interpreters/Session.cpp:553: DB::Session::makeSessionContext() @ 0x0000000018afdf43 6. ./build_docker/./src/Server/TCPHandler.cpp:346: DB::TCPHandler::runImpl() @ 0x000000001bbd912c 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:29:59.862121 [ 45958 ] {} ServerErrorHandler: Code: 700. DB::Exception: User 504fcf3b-438f-f207-50c9-a2c8501f4ba9 has overflown session count 1. (USER_SESSION_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x00000000089ee886 4. ./build_docker/./src/Interpreters/SessionTracker.cpp:40: DB::SessionTracker::trackSession(StrongTypedef, DB::UUIDTag> const&, DB::SessionInfo const&, unsigned long) @ 0x0000000018b1526a 5. ./build_docker/./src/Interpreters/Session.cpp:553: DB::Session::makeSessionContext() @ 0x0000000018afdf43 6. ./build_docker/./src/Server/TCPHandler.cpp:346: DB::TCPHandler::runImpl() @ 0x000000001bbd912c 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:30:00.321122 [ 42861 ] {02832_alter_max_sessions_query_46268_1_1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47150) (comment: 02832_alter_max_sessions_for_user.sh) (query 1, line 1) (in query: SELECT sleepEachRow(0.1) FROM numbers(1200)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:30:00.323248 [ 42861 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:30:03.058242 [ 46344 ] {} TCPHandler: TCPHandler: Code: 700. DB::Exception: User 504fcf3b-438f-f207-50c9-a2c8501f4ba9 has overflown session count 2. (USER_SESSION_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x00000000089ee886 4. ./build_docker/./src/Interpreters/SessionTracker.cpp:40: DB::SessionTracker::trackSession(StrongTypedef, DB::UUIDTag> const&, DB::SessionInfo const&, unsigned long) @ 0x0000000018b1526a 5. ./build_docker/./src/Interpreters/Session.cpp:553: DB::Session::makeSessionContext() @ 0x0000000018afdf43 6. ./build_docker/./src/Server/TCPHandler.cpp:346: DB::TCPHandler::runImpl() @ 0x000000001bbd912c 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:30:03.058527 [ 46344 ] {} ServerErrorHandler: Code: 700. DB::Exception: User 504fcf3b-438f-f207-50c9-a2c8501f4ba9 has overflown session count 2. (USER_SESSION_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x00000000089ee886 4. ./build_docker/./src/Interpreters/SessionTracker.cpp:40: DB::SessionTracker::trackSession(StrongTypedef, DB::UUIDTag> const&, DB::SessionInfo const&, unsigned long) @ 0x0000000018b1526a 5. ./build_docker/./src/Interpreters/Session.cpp:553: DB::Session::makeSessionContext() @ 0x0000000018afdf43 6. ./build_docker/./src/Server/TCPHandler.cpp:346: DB::TCPHandler::runImpl() @ 0x000000001bbd912c 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:30:03.588653 [ 42861 ] {02832_alter_max_sessions_query_46268_1_2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47196) (comment: 02832_alter_max_sessions_for_user.sh) (query 1, line 1) (in query: SELECT sleepEachRow(0.1) FROM numbers(1200)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:30:03.590288 [ 42861 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:30:04.060064 [ 45958 ] {02832_alter_max_sessions_query_46268_2_2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47218) (comment: 02832_alter_max_sessions_for_user.sh) (query 1, line 1) (in query: SELECT sleepEachRow(0.1) FROM numbers(1200)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:30:04.061607 [ 45958 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000018ac7b2b 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a3e 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:30:05.004596 [ 45958 ] {18421295-6ba0-4f17-b4e7-ccff9685542d} executeQuery: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by query. (READONLY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47296) (comment: 02832_alter_max_sessions_for_user.sh) (query 1, line 1) (in query: SET max_sessions_for_user = 1 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x0000000016e42046 4. ./build_docker/./src/Access/SettingsConstraints.cpp:385: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40f32 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016e40223 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000181a89f6 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000018a200ec 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:30:05.005915 [ 45958 ] {} TCPHandler: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by query. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x0000000016e42046 4. ./build_docker/./src/Access/SettingsConstraints.cpp:385: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40f32 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016e40223 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000181a89f6 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000018a200ec 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:30:05.581705 [ 45958 ] {} TCPHandler: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by query. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x0000000016e42046 4. ./build_docker/./src/Access/SettingsConstraints.cpp:385: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40f32 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000016e40388 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000181a8486 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000181a8b7b 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000001bbf3757 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001bbe96b5 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000001bbd9ee7 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:30:05.633937 [ 45958 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000001bbe9892 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000001bbd9ee7 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:30:06.095835 [ 45958 ] {b4970c18-7708-40dc-b06a-e3d726fcae8e} executeQuery: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by user. (READONLY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47318) (comment: 02832_alter_max_sessions_for_user.sh) (query 1, line 1) (in query: CREATE USER 02832_alter_max_sessions_user_two_46268 SETTINGS max_sessions_for_user = 1 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x0000000016e42046 4. ./build_docker/./src/Access/SettingsConstraints.cpp:385: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40f32 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f8b8 7. ./build_docker/./src/Access/SettingsConstraints.cpp:143: DB::SettingsConstraints::check(DB::Settings const&, DB::AlterSettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f6b0 8. ./build_docker/./src/Interpreters/Context.cpp:2669: DB::Context::checkSettingsConstraintsWithLock(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a7fa6 9. ./build_docker/./src/Interpreters/Context.cpp:2710: DB::Context::checkSettingsConstraints(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a88bb 10. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:237: DB::InterpreterCreateUserQuery::execute() @ 0x000000001a263fc6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:30:06.097187 [ 45958 ] {} TCPHandler: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by user. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x0000000016e42046 4. ./build_docker/./src/Access/SettingsConstraints.cpp:385: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40f32 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f8b8 7. ./build_docker/./src/Access/SettingsConstraints.cpp:143: DB::SettingsConstraints::check(DB::Settings const&, DB::AlterSettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f6b0 8. ./build_docker/./src/Interpreters/Context.cpp:2669: DB::Context::checkSettingsConstraintsWithLock(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a7fa6 9. ./build_docker/./src/Interpreters/Context.cpp:2710: DB::Context::checkSettingsConstraints(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a88bb 10. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:237: DB::InterpreterCreateUserQuery::execute() @ 0x000000001a263fc6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:30:06.583648 [ 45958 ] {a29031e3-28c7-451f-8f16-16c33965c39b} executeQuery: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by user. (READONLY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47332) (comment: 02832_alter_max_sessions_for_user.sh) (query 1, line 1) (in query: ALTER USER 02832_alter_max_sessions_user_46268 SETTINGS max_sessions_for_user = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x0000000016e42046 4. ./build_docker/./src/Access/SettingsConstraints.cpp:385: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40f32 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f8b8 7. ./build_docker/./src/Access/SettingsConstraints.cpp:143: DB::SettingsConstraints::check(DB::Settings const&, DB::AlterSettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f6b0 8. ./build_docker/./src/Interpreters/Context.cpp:2669: DB::Context::checkSettingsConstraintsWithLock(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a7fa6 9. ./build_docker/./src/Interpreters/Context.cpp:2710: DB::Context::checkSettingsConstraints(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a88bb 10. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:237: DB::InterpreterCreateUserQuery::execute() @ 0x000000001a263fc6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:30:06.585260 [ 45958 ] {} TCPHandler: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by user. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x0000000016e42046 4. ./build_docker/./src/Access/SettingsConstraints.cpp:385: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40f32 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f8b8 7. ./build_docker/./src/Access/SettingsConstraints.cpp:143: DB::SettingsConstraints::check(DB::Settings const&, DB::AlterSettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f6b0 8. ./build_docker/./src/Interpreters/Context.cpp:2669: DB::Context::checkSettingsConstraintsWithLock(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a7fa6 9. ./build_docker/./src/Interpreters/Context.cpp:2710: DB::Context::checkSettingsConstraints(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a88bb 10. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:237: DB::InterpreterCreateUserQuery::execute() @ 0x000000001a263fc6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:30:07.154320 [ 45958 ] {20ec3990-0aea-492b-8a7a-37be18b1c5fd} executeQuery: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by role. (READONLY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52854) (comment: 02832_alter_max_sessions_for_user.sh) (query 1, line 1) (in query: CREATE ROLE 02832_alter_max_sessions_role_46268 SETTINGS max_sessions_for_user = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x0000000016e42046 4. ./build_docker/./src/Access/SettingsConstraints.cpp:385: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40f32 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f8b8 7. ./build_docker/./src/Access/SettingsConstraints.cpp:143: DB::SettingsConstraints::check(DB::Settings const&, DB::AlterSettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f6b0 8. ./build_docker/./src/Interpreters/Context.cpp:2669: DB::Context::checkSettingsConstraintsWithLock(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a7fa6 9. ./build_docker/./src/Interpreters/Context.cpp:2710: DB::Context::checkSettingsConstraints(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a88bb 10. ./build_docker/./src/Interpreters/Access/InterpreterCreateRoleQuery.cpp:66: DB::InterpreterCreateRoleQuery::execute() @ 0x000000001a25bcf8 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:30:07.155869 [ 45958 ] {} TCPHandler: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by role. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x0000000016e42046 4. ./build_docker/./src/Access/SettingsConstraints.cpp:385: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40f32 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f8b8 7. ./build_docker/./src/Access/SettingsConstraints.cpp:143: DB::SettingsConstraints::check(DB::Settings const&, DB::AlterSettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f6b0 8. ./build_docker/./src/Interpreters/Context.cpp:2669: DB::Context::checkSettingsConstraintsWithLock(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a7fa6 9. ./build_docker/./src/Interpreters/Context.cpp:2710: DB::Context::checkSettingsConstraints(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a88bb 10. ./build_docker/./src/Interpreters/Access/InterpreterCreateRoleQuery.cpp:66: DB::InterpreterCreateRoleQuery::execute() @ 0x000000001a25bcf8 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:30:08.092391 [ 45958 ] {9cc78176-eac3-4a67-a35b-4291b8ef32fe} executeQuery: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by role. (READONLY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52878) (comment: 02832_alter_max_sessions_for_user.sh) (query 1, line 1) (in query: ALTER ROLE 02832_alter_max_sessions_role_46268 SETTINGS max_sessions_for_user = 1 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x0000000016e42046 4. ./build_docker/./src/Access/SettingsConstraints.cpp:385: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40f32 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f8b8 7. ./build_docker/./src/Access/SettingsConstraints.cpp:143: DB::SettingsConstraints::check(DB::Settings const&, DB::AlterSettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f6b0 8. ./build_docker/./src/Interpreters/Context.cpp:2669: DB::Context::checkSettingsConstraintsWithLock(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a7fa6 9. ./build_docker/./src/Interpreters/Context.cpp:2710: DB::Context::checkSettingsConstraints(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a88bb 10. ./build_docker/./src/Interpreters/Access/InterpreterCreateRoleQuery.cpp:66: DB::InterpreterCreateRoleQuery::execute() @ 0x000000001a25bcf8 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:30:08.094045 [ 45958 ] {} TCPHandler: Code: 164. DB::Exception: Setting max_sessions_for_user is not allowed to be set by role. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, std::basic_string_view>>(int, FormatStringHelperImpl>&>::type, std::type_identity>>::type>, std::basic_string_view>&, std::basic_string_view>&&) @ 0x0000000016e42046 4. ./build_docker/./src/Access/SettingsConstraints.cpp:385: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40f32 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f8b8 7. ./build_docker/./src/Access/SettingsConstraints.cpp:143: DB::SettingsConstraints::check(DB::Settings const&, DB::AlterSettingsProfileElements const&, DB::SettingSource) const @ 0x0000000016e3f6b0 8. ./build_docker/./src/Interpreters/Context.cpp:2669: DB::Context::checkSettingsConstraintsWithLock(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a7fa6 9. ./build_docker/./src/Interpreters/Context.cpp:2710: DB::Context::checkSettingsConstraints(DB::AlterSettingsProfileElements const&, DB::SettingSource) @ 0x00000000181a88bb 10. ./build_docker/./src/Interpreters/Access/InterpreterCreateRoleQuery.cpp:66: DB::InterpreterCreateRoleQuery::execute() @ 0x000000001a25bcf8 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:30:17.596930 [ 42861 ] {dc497e44-67a6-4773-99cc-3a1d5270b1c0} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'http://localhost:11111/test/a.myext' in scope SELECT * FROM `http://localhost:11111/test/a.myext`. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48784) (comment: 02724_database_s3.sh) (query 4, line 5) (in query: SELECT * FROM "http://localhost:11111/test/a.myext" ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:30:17.598437 [ 42861 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'http://localhost:11111/test/a.myext' in scope SELECT * FROM `http://localhost:11111/test/a.myext`. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:30:18.103622 [ 42861 ] {5cad2460-8a5f-4e0a-9202-5920f90a76e9} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'abacaba' in scope SELECT * FROM abacaba. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48792) (comment: 02724_database_s3.sh) (query 2, line 3) (in query: SELECT * FROM "abacaba" ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:30:18.105399 [ 42861 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'abacaba' in scope SELECT * FROM abacaba. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:30:33.921163 [ 42863 ] {028b7195-1c2c-4231-8198-c6e1374271a4} executeQuery: Code: 719. DB::Exception: The query result was not cached because the query contains a system table. Use setting `query_cache_system_table_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_SYSTEM_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46622) (comment: 02494_query_cache_system_tables.sql) (query 3, line 7) (in query: -- Test that the query cache rejects queries that involve system tables. SELECT * FROM system.one SETTINGS use_query_cache = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1478: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e18c8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:30:33.922288 [ 42863 ] {} TCPHandler: Code: 719. DB::Exception: The query result was not cached because the query contains a system table. Use setting `query_cache_system_table_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_SYSTEM_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1478: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e18c8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:30:33.959389 [ 42863 ] {aaaf4b22-c7b9-423d-93d1-55847057e3a9} executeQuery: Code: 719. DB::Exception: The query result was not cached because the query contains a system table. Use setting `query_cache_system_table_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_SYSTEM_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46622) (comment: 02494_query_cache_system_tables.sql) (query 7, line 14) (in query: -- Test that the query cache rejects queries that involve system tables. SELECT * FROM system.one SETTINGS use_query_cache = 1, query_cache_system_table_handling = 'throw';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1478: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e18c8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:30:33.960225 [ 42863 ] {} TCPHandler: Code: 719. DB::Exception: The query result was not cached because the query contains a system table. Use setting `query_cache_system_table_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_SYSTEM_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1478: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e18c8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:30:34.139156 [ 42863 ] {ad51c8de-5b05-4ce5-b717-7e446c5bd6ef} executeQuery: Code: 719. DB::Exception: The query result was not cached because the query contains a system table. Use setting `query_cache_system_table_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_SYSTEM_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46622) (comment: 02494_query_cache_system_tables.sql) (query 22, line 43) (in query: -- information_schema is also treated as a system table SELECT * FROM information_schema.tables SETTINGS use_query_cache = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1478: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e18c8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:30:34.140566 [ 42863 ] {} TCPHandler: Code: 719. DB::Exception: The query result was not cached because the query contains a system table. Use setting `query_cache_system_table_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_SYSTEM_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1478: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e18c8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:30:34.177621 [ 42863 ] {3cadf6d1-bffe-4a0a-8e8a-029c5e3ff407} executeQuery: Code: 719. DB::Exception: The query result was not cached because the query contains a system table. Use setting `query_cache_system_table_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_SYSTEM_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46622) (comment: 02494_query_cache_system_tables.sql) (query 23, line 45) (in query: SELECT * FROM INFORMATION_SCHEMA.TABLES SETTINGS use_query_cache = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1478: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e18c8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:30:34.179094 [ 42863 ] {} TCPHandler: Code: 719. DB::Exception: The query result was not cached because the query contains a system table. Use setting `query_cache_system_table_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_SYSTEM_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1478: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e18c8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:30:34.230152 [ 42863 ] {bb018aa9-86bc-453f-88e6-7cf88ee347b7} executeQuery: Code: 719. DB::Exception: The query result was not cached because the query contains a system table. Use setting `query_cache_system_table_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_SYSTEM_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46622) (comment: 02494_query_cache_system_tables.sql) (query 28, line 53) (in query: -- System tables can be "hidden" inside e.g. table functions SELECT * FROM clusterAllReplicas('test_shard_localhost', system.one) SETTINGS use_query_cache = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1478: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e18c8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:30:34.231212 [ 42863 ] {} TCPHandler: Code: 719. DB::Exception: The query result was not cached because the query contains a system table. Use setting `query_cache_system_table_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_SYSTEM_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1478: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e18c8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:30:34.246111 [ 42863 ] {7737122a-2f3a-4262-aff3-066875d6f395} executeQuery: Code: 719. DB::Exception: The query result was not cached because the query contains a system table. Use setting `query_cache_system_table_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_SYSTEM_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46622) (comment: 02494_query_cache_system_tables.sql) (query 29, line 55) (in query: SELECT * FROM clusterAllReplicas('test_shard_localhost', 'system.one') SETTINGS use_query_cache = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1478: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e18c8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:30:34.247237 [ 42863 ] {} TCPHandler: Code: 719. DB::Exception: The query result was not cached because the query contains a system table. Use setting `query_cache_system_table_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_SYSTEM_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1478: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e18c8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:30:34.303409 [ 42863 ] {4cf5790b-cd1e-4bad-b372-c39138461de2} executeQuery: Code: 719. DB::Exception: The query result was not cached because the query contains a system table. Use setting `query_cache_system_table_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_SYSTEM_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:46622) (comment: 02494_query_cache_system_tables.sql) (query 36, line 67) (in query: SElECT * FROM system.system SETTINGS use_query_cache = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1478: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e18c8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:30:34.304240 [ 42863 ] {} TCPHandler: Code: 719. DB::Exception: The query result was not cached because the query contains a system table. Use setting `query_cache_system_table_handling = 'save'` or `= 'ignore'` to cache the query result regardless or to omit caching. (QUERY_CACHE_USED_WITH_SYSTEM_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1478: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e18c8f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 13. __tsan_thread_start_func @ 0x0000000008756428 14. ? @ 0x00007fecd6763ac3 15. ? @ 0x00007fecd67f5850 2025.07.28 06:31:01.129654 [ 46344 ] {1fdc4a20-3fc3-49e4-9730-a15ed4d5c3a0} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a Parquet format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a Parquet format file. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43768) (comment: 02481_s3_throw_if_mismatch_files.sql) (query 5, line 10) (in query: select a, b from s3(s3_conn, filename='test_02481_mismatch_filesxxx*', format=Parquet);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000a1fa4c6 4. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:201: DB::ReadBufferIterator::next() @ 0x00000000165d9124 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcb8734 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:517: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000165cf2df 8. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:68: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x00000000166acf94 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:134: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool) @ 0x00000000165ca757 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&) @ 0x0000000013d55507 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&) @ 0x0000000013d551fe 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013d1b68f 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 14. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:31:01.130983 [ 46344 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a Parquet format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a Parquet format file. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000a1fa4c6 4. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:201: DB::ReadBufferIterator::next() @ 0x00000000165d9124 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcb8734 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:517: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000165cf2df 8. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:68: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x00000000166acf94 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:134: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool) @ 0x00000000165ca757 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&) @ 0x0000000013d55507 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&) @ 0x0000000013d551fe 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013d1b68f 13. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 14. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:31:01.266535 [ 46344 ] {505e9c29-738e-4faa-80ac-fdde61aca346} executeQuery: Code: 107. DB::Exception: Can not match any files with path test_02481_mismatch_filesxxx*: The table structure cannot be extracted from a Parquet format file. You can specify the structure manually. (FILE_DOESNT_EXIST) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43768) (comment: 02481_s3_throw_if_mismatch_files.sql) (query 6, line 12) (in query: select a, b from s3(s3_conn, filename='test_02481_mismatch_filesxxx*', format=Parquet) settings s3_throw_on_zero_files_match=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:747: DB::StorageObjectStorageSource::GlobIterator::next(unsigned long) @ 0x000000001666782a 5. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:193: DB::ReadBufferIterator::next() @ 0x00000000165d809e 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcb8734 7. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:517: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000165cf2df 9. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:68: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x00000000166acf94 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:134: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool) @ 0x00000000165ca757 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&) @ 0x0000000013d55507 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&) @ 0x0000000013d551fe 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013d1b68f 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:31:01.267753 [ 46344 ] {} TCPHandler: Code: 107. DB::Exception: Can not match any files with path test_02481_mismatch_filesxxx*: The table structure cannot be extracted from a Parquet format file. You can specify the structure manually. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:747: DB::StorageObjectStorageSource::GlobIterator::next(unsigned long) @ 0x000000001666782a 5. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:193: DB::ReadBufferIterator::next() @ 0x00000000165d809e 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcb8734 7. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:517: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000165cf2df 9. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:68: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x00000000166acf94 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:134: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool) @ 0x00000000165ca757 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, std::allocator, 0>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&) @ 0x0000000013d55507 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, std::nullptr_t, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool const&, std::nullptr_t&&) @ 0x0000000013d551fe 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013d1b68f 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 2025.07.28 06:31:02.135659 [ 46344 ] {7382679a-3f9b-4bab-a07b-ac6ba70ca071} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02458_data.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43778) (comment: 02458_use_structure_from_insertion_table.sql) (query 10, line 14) (in query: insert into test select x + 1, y from file(02458_data.jsonl);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbcdce 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabc85b 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001aabcf8f 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000013cbd11d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000013cba627 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cbeb14 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:31:02.137089 [ 46344 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02458_data.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbcdce 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabc85b 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001aabcf8f 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000013cbd11d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000013cba627 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cbeb14 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:31:02.189162 [ 46344 ] {f1040f65-52b4-4ffe-98cf-d833939f1f7c} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'c1' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02458_data.jsoncompacteachrow). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43778) (comment: 02458_use_structure_from_insertion_table.sql) (query 13, line 17) (in query: insert into test select x, 1 from file(02458_data.jsoncompacteachrow);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbcdce 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabc85b 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001aabcf8f 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000013cbd11d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000013cba627 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cbeb14 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:31:02.190305 [ 46344 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'c1' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02458_data.jsoncompacteachrow). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbcdce 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabc85b 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001aabcf8f 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000013cbd11d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000013cba627 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cbeb14 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:31:02.199039 [ 46344 ] {db26dda7-616f-4a3f-bec3-1075e656705e} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'c1' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02458_data.jsoncompacteachrow). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43778) (comment: 02458_use_structure_from_insertion_table.sql) (query 14, line 18) (in query: insert into test select x, y from file(02458_data.jsoncompacteachrow);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbcdce 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabc85b 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001aabcf8f 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000013cbd11d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000013cba627 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cbeb14 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:31:02.200883 [ 46344 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'c1' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02458_data.jsoncompacteachrow). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbcdce 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabc85b 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001aabcf8f 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000013cbd11d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000013cba627 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cbeb14 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:31:02.213635 [ 46344 ] {4c1030b6-95de-4961-acc0-75ff9deb8043} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'c1' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02458_data.jsoncompacteachrow). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43778) (comment: 02458_use_structure_from_insertion_table.sql) (query 15, line 19) (in query: insert into test select x + 1, y from file(02458_data.jsoncompacteachrow);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbcdce 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabc85b 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001aabcf8f 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000013cbd11d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000013cba627 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cbeb14 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:31:02.214621 [ 46344 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'c1' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02458_data.jsoncompacteachrow). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbcdce 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabc85b 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001aabcf8f 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000013cbd11d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000013cba627 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cbeb14 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:31:02.224271 [ 46344 ] {92c0ed62-ff28-4d34-ac93-a0d71e1b4feb} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'c1' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02458_data.jsoncompacteachrow). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43778) (comment: 02458_use_structure_from_insertion_table.sql) (query 16, line 20) (in query: insert into test select x, z from file(02458_data.jsoncompacteachrow);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbcdce 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabc85b 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001aabcf8f 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000013cbd11d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000013cba627 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cbeb14 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:31:02.225347 [ 46344 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'c1' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.6.10634.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02458_data.jsoncompacteachrow). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000eb74966 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbcdce 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabc85b 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001aabcf8f 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000013cbd11d 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000013cba627 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cbeb14 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 24. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 25. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 2025.07.28 06:31:02.346774 [ 46344 ] {0f10ed80-13c4-4d30-a81a-4e30978c6550} executeQuery: Code: 636. DB::Exception: Table function 'input' was used without structure argument but structure could not be determined automatically. Please, provide structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43778) (comment: 02458_use_structure_from_insertion_table.sql) (query 18, line 23) (in query: insert into test select x, y from input() format CSV ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/TableFunctions/TableFunctionInput.cpp:75: DB::(anonymous namespace)::TableFunctionInput::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013ccb526 5. ./build_docker/./src/TableFunctions/TableFunctionInput.cpp:87: DB::(anonymous namespace)::TableFunctionInput::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013ccb82d 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 7. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:31:02.347721 [ 46344 ] {} TCPHandler: Code: 636. DB::Exception: Table function 'input' was used without structure argument but structure could not be determined automatically. Please, provide structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/TableFunctions/TableFunctionInput.cpp:75: DB::(anonymous namespace)::TableFunctionInput::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013ccb526 5. ./build_docker/./src/TableFunctions/TableFunctionInput.cpp:87: DB::(anonymous namespace)::TableFunctionInput::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013ccb82d 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 7. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:31:02.468480 [ 46344 ] {bee61d4c-10b9-4d46-a7ce-aadd7736260a} executeQuery: Code: 636. DB::Exception: Table function 'input' was used without structure argument but structure could not be determined automatically. Please, provide structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43778) (comment: 02458_use_structure_from_insertion_table.sql) (query 27, line 35) (in query: insert into test select c1 from input() format CSV ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/TableFunctions/TableFunctionInput.cpp:75: DB::(anonymous namespace)::TableFunctionInput::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013ccb526 5. ./build_docker/./src/TableFunctions/TableFunctionInput.cpp:87: DB::(anonymous namespace)::TableFunctionInput::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013ccb82d 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 7. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:31:02.469232 [ 46344 ] {} TCPHandler: Code: 636. DB::Exception: Table function 'input' was used without structure argument but structure could not be determined automatically. Please, provide structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/TableFunctions/TableFunctionInput.cpp:75: DB::(anonymous namespace)::TableFunctionInput::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013ccb526 5. ./build_docker/./src/TableFunctions/TableFunctionInput.cpp:87: DB::(anonymous namespace)::TableFunctionInput::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013ccb82d 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 7. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:31:07.300150 [ 46344 ] {e23f6dd2-73ae-40d3-abde-37fde965b98b} executeQuery: Code: 305. DB::Exception: There is a local database rdb_test_rnaksl1p, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55316) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: system drop database replica 's1|r1' from database rdb_test_rnaksl1p), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1166: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x0000000018e6ca51 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1177: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e60fcb 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:07.301595 [ 46344 ] {} TCPHandler: Code: 305. DB::Exception: There is a local database rdb_test_rnaksl1p, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1166: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x0000000018e6ca51 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1177: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e60fcb 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:07.804295 [ 46344 ] {f7e9b1b2-a8e1-4bed-b056-49137f630528} executeQuery: Code: 305. DB::Exception: There is a local database rdb_test_rnaksl1p, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55332) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: system drop database replica 'r1' from shard 's1' from database rdb_test_rnaksl1p), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1166: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x0000000018e6ca51 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1177: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e60fcb 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:07.806157 [ 46344 ] {} TCPHandler: Code: 305. DB::Exception: There is a local database rdb_test_rnaksl1p, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1166: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x0000000018e6ca51 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1177: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e60fcb 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:08.392548 [ 46344 ] {0e167cf2-afca-40c5-9638-035e1f4a58ff} executeQuery: Code: 305. DB::Exception: There is a local database rdb_test_rnaksl1p, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55348) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: system drop database replica 's1|r1' from zkpath '/test/test_rnaksl1p/rdb'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1166: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x0000000018e6ca51 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1214: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e62414 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:08.394236 [ 46344 ] {} TCPHandler: Code: 305. DB::Exception: There is a local database rdb_test_rnaksl1p, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1166: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x0000000018e6ca51 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1214: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e62414 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:08.889458 [ 46344 ] {7432dded-69ff-4d75-89c1-aab0ca7a0d6b} executeQuery: Code: 305. DB::Exception: There is a local database rdb_test_rnaksl1p, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55350) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: system drop database replica 's1|r1' from zkpath '/test/test_rnaksl1p/rdb/'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1166: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x0000000018e6ca51 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1214: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e62414 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:08.890900 [ 46344 ] {} TCPHandler: Code: 305. DB::Exception: There is a local database rdb_test_rnaksl1p, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1166: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x0000000018e6ca51 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1214: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e62414 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:09.403550 [ 46344 ] {ffe386f5-0cf2-4e7a-954c-c00b469f50ac} executeQuery: Code: 305. DB::Exception: There is a local database rdb_test_rnaksl1p, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55356) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: system drop database replica 'r1' from shard 's1' from zkpath '/test/test_rnaksl1p/rdb/'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1166: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x0000000018e6ca51 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1214: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e62414 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:09.405287 [ 46344 ] {} TCPHandler: Code: 305. DB::Exception: There is a local database rdb_test_rnaksl1p, which has the same path in ZooKeeper and the same replica name. Please check the path in query. If you want to drop replica of this database, use `DROP DATABASE`. (TABLE_WAS_NOT_DROPPED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1166: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&)::$_0::operator()(DB::DatabaseReplicated const*, DB::ASTSystemQuery const&) const @ 0x0000000018e6ca51 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1214: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e62414 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:09.984670 [ 46344 ] {7538de70-1105-40f6-a9ed-bf6bdced1a52} executeQuery: Code: 36. DB::Exception: Path /test/test_rnaksl1p does not look like a path of Replicated database. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55372) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: system drop database replica 's1|r1' from zkpath '/test/test_rnaksl1p/'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1630: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x00000000176e3a72 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1216: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e624b9 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:09.986094 [ 46344 ] {} TCPHandler: Code: 36. DB::Exception: Path /test/test_rnaksl1p does not look like a path of Replicated database. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1630: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x00000000176e3a72 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1216: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e624b9 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:10.579848 [ 46344 ] {b63e5ab7-41c5-403e-aad7-47ac3f07d81e} executeQuery: Code: 36. DB::Exception: Replica s2|r1 does not exist (database path: /test/test_rnaksl1p/rdb). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55376) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: system drop database replica 's2|r1' from zkpath '/test/test_rnaksl1p/rdb'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x0000000010ea60a6 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1637: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x00000000176e34c7 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1216: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e624b9 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:10.581133 [ 46344 ] {} TCPHandler: Code: 36. DB::Exception: Replica s2|r1 does not exist (database path: /test/test_rnaksl1p/rdb). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x0000000010ea60a6 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1637: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x00000000176e34c7 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1216: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e624b9 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:11.072197 [ 46344 ] {12efdc85-4a3b-42f1-aacc-b9986052a5d0} executeQuery: Code: 36. DB::Exception: Replica r1|s1 does not exist (database path: /test/test_rnaksl1p/rdb). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55380) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: system drop database replica 's1' from shard 'r1' from zkpath '/test/test_rnaksl1p/rdb'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x0000000010ea60a6 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1637: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x00000000176e34c7 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1216: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e624b9 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:11.073362 [ 46344 ] {} TCPHandler: Code: 36. DB::Exception: Replica r1|s1 does not exist (database path: /test/test_rnaksl1p/rdb). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x0000000010ea60a6 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1637: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x00000000176e34c7 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1216: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e624b9 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:11.577537 [ 46344 ] {7d9bb195-2448-4fec-85c9-e075fa705d3b} executeQuery: Code: 36. DB::Exception: Replica s1|s1|r1 does not exist (database path: /test/test_rnaksl1p/rdb). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55390) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: system drop database replica 's1|r1' from shard 's1' from zkpath '/test/test_rnaksl1p/rdb'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x0000000010ea60a6 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1637: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x00000000176e34c7 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1216: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e624b9 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:11.579280 [ 46344 ] {} TCPHandler: Code: 36. DB::Exception: Replica s1|s1|r1 does not exist (database path: /test/test_rnaksl1p/rdb). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x0000000010ea60a6 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1637: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x00000000176e34c7 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1216: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e624b9 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:12.146423 [ 46344 ] {f4f34d61-1fe8-4bc2-8542-7367fe35740c} executeQuery: Code: 36. DB::Exception: Invalid replica name, '/' is not allowed: s2/r1. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55396) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: system drop database replica 's2/r1' from zkpath '/test/test_rnaksl1p/rdb'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1621: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x00000000176e3b01 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1216: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e624b9 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:12.147849 [ 46344 ] {} TCPHandler: Code: 36. DB::Exception: Invalid replica name, '/' is not allowed: s2/r1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1621: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x00000000176e3b01 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1216: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e624b9 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:12.881292 [ 17262 ] {} DDLWorker(rdb_test_rnaksl1p_2): Error on initialization of rdb_test_rnaksl1p_2: Code: 57. DB::Exception: Directory for table data store/cda/cdae1e91-a45e-4e4f-a35f-b4397e5347ec/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:13.137936 [ 17252 ] {} DDLWorker(rdb_test_rnaksl1p_3): Error on initialization of rdb_test_rnaksl1p_3: Code: 57. DB::Exception: Directory for table data store/cda/cdae1e91-a45e-4e4f-a35f-b4397e5347ec/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:14.511509 [ 46344 ] {bdff144e-8cf9-4acd-931d-771cc167dc27} executeQuery: Code: 36. DB::Exception: Replica s1|r1 is active, cannot drop it (database path: /test/test_rnaksl1p/rdb). (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55436) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: system drop database replica 's1|r1' from database rdb_test_rnaksl1p_2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x0000000010ea60a6 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1642: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x00000000176e3b9a 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1178: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e60fed 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:14.512882 [ 46344 ] {} TCPHandler: Code: 36. DB::Exception: Replica s1|r1 is active, cannot drop it (database path: /test/test_rnaksl1p/rdb). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x0000000010ea60a6 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1642: DB::DatabaseReplicated::dropReplica(DB::DatabaseReplicated*, String const&, String const&, String const&, bool) @ 0x00000000176e3b9a 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1178: DB::InterpreterSystemQuery::dropDatabaseReplica(DB::ASTSystemQuery&) @ 0x0000000018e60fed 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:739: DB::InterpreterSystemQuery::execute() @ 0x0000000018e55935 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:17.214298 [ 42859 ] {} DDLWorker(rdb_test_rnaksl1p_9): Error on initialization of rdb_test_rnaksl1p_9: Code: 57. DB::Exception: Directory for table data store/77a/77a8aa81-ac7a-4bc3-87c8-b381c95e984e/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:17.900214 [ 17262 ] {} DDLWorker(rdb_test_rnaksl1p_2): Error on initialization of rdb_test_rnaksl1p_2: Code: 57. DB::Exception: Directory for table data store/dc1/dc1e859e-697a-497c-9339-d7e1e4592376/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:18.158506 [ 17252 ] {} DDLWorker(rdb_test_rnaksl1p_3): Error on initialization of rdb_test_rnaksl1p_3: Code: 57. DB::Exception: Directory for table data store/77a/77a8aa81-ac7a-4bc3-87c8-b381c95e984e/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:22.920826 [ 17262 ] {} DDLWorker(rdb_test_rnaksl1p_2): Error on initialization of rdb_test_rnaksl1p_2: Code: 57. DB::Exception: Directory for table data store/77a/77a8aa81-ac7a-4bc3-87c8-b381c95e984e/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:23.176317 [ 17252 ] {} DDLWorker(rdb_test_rnaksl1p_3): Error on initialization of rdb_test_rnaksl1p_3: Code: 57. DB::Exception: Directory for table data store/77a/77a8aa81-ac7a-4bc3-87c8-b381c95e984e/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:27.976415 [ 17262 ] {} DDLWorker(rdb_test_rnaksl1p_2): Error on initialization of rdb_test_rnaksl1p_2: Code: 57. DB::Exception: Directory for table data store/dc1/dc1e859e-697a-497c-9339-d7e1e4592376/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:28.208252 [ 17252 ] {} DDLWorker(rdb_test_rnaksl1p_3): Error on initialization of rdb_test_rnaksl1p_3: Code: 57. DB::Exception: Directory for table data store/77a/77a8aa81-ac7a-4bc3-87c8-b381c95e984e/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:28.620096 [ 46344 ] {7b8aa4b8-5486-485c-b7a5-81760e090504} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_rnaksl1p/rdb/log/query-0000000009 is not finished on 3 of 4 hosts (0 of them are currently executing the task, 2 are inactive). They are going to execute the query in background. Was waiting for 5.300005002 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59454) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: create table rdb_test_rnaksl1p.t22 (n int) engine=Log), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x0000000018ae4985 4. ./build_docker/./src/Interpreters/ReplicatedDatabaseQueryStatusSource.cpp:92: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x0000000018ae3a88 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f7373 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:31:28.621679 [ 46344 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_rnaksl1p/rdb/log/query-0000000009 is not finished on 3 of 4 hosts (0 of them are currently executing the task, 2 are inactive). They are going to execute the query in background. Was waiting for 5.300005002 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x0000000018ae4985 4. ./build_docker/./src/Interpreters/ReplicatedDatabaseQueryStatusSource.cpp:92: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x0000000018ae3a88 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f7373 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd0efac 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000001bd0e757 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000001bbdad60 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 12. __tsan_thread_start_func @ 0x0000000008756428 13. ? @ 0x00007fecd6763ac3 14. ? @ 0x00007fecd67f5850 2025.07.28 06:31:32.994779 [ 17262 ] {} DDLWorker(rdb_test_rnaksl1p_2): Error on initialization of rdb_test_rnaksl1p_2: Code: 57. DB::Exception: Directory for table data store/77a/77a8aa81-ac7a-4bc3-87c8-b381c95e984e/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:33.228597 [ 17252 ] {} DDLWorker(rdb_test_rnaksl1p_3): Error on initialization of rdb_test_rnaksl1p_3: Code: 57. DB::Exception: Directory for table data store/77a/77a8aa81-ac7a-4bc3-87c8-b381c95e984e/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:34.441466 [ 46344 ] {b08e4d18-7752-4012-9636-6bdbc68f4a9e} executeQuery: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_rnaksl1p/rdb/log/query-0000000010 is not finished on 3 of 4 hosts (0 of them are currently executing the task, 2 are inactive). They are going to execute the query in background. Was waiting for 5.296004975 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47450) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: create table rdb_test_rnaksl1p.t33 (n int) engine=Log), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x0000000018ae4985 4. ./build_docker/./src/Interpreters/ReplicatedDatabaseQueryStatusSource.cpp:92: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x0000000018ae3a88 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f7373 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:31:34.442954 [ 46344 ] {} TCPHandler: Code: 159. DB::Exception: ReplicatedDatabase DDL task /test/test_rnaksl1p/rdb/log/query-0000000010 is not finished on 3 of 4 hosts (0 of them are currently executing the task, 2 are inactive). They are going to execute the query in background. Was waiting for 5.296004975 seconds, which is longer than distributed_ddl_task_timeout. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, unsigned long&, unsigned long&&, unsigned long&, unsigned long&&, double&&, char const*&&) @ 0x0000000018ae4985 4. ./build_docker/./src/Interpreters/ReplicatedDatabaseQueryStatusSource.cpp:92: DB::ReplicatedDatabaseQueryStatusSource::handleTimeoutExceeded() @ 0x0000000018ae3a88 5. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:197: DB::DistributedQueryStatusSource::generate() @ 0x00000000182f7373 6. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 7. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:31:38.023490 [ 17262 ] {} DDLWorker(rdb_test_rnaksl1p_2): Error on initialization of rdb_test_rnaksl1p_2: Code: 57. DB::Exception: Directory for table data store/b07/b0793e07-2e9e-4a1f-971a-0e0cb512abff/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:38.247091 [ 17252 ] {} DDLWorker(rdb_test_rnaksl1p_3): Error on initialization of rdb_test_rnaksl1p_3: Code: 57. DB::Exception: Directory for table data store/77a/77a8aa81-ac7a-4bc3-87c8-b381c95e984e/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:40.724913 [ 42834 ] {} DDLWorker(rdb_test_rnaksl1p_9): Error on initialization of rdb_test_rnaksl1p_9: Code: 57. DB::Exception: Directory for table data store/77a/77a8aa81-ac7a-4bc3-87c8-b381c95e984e/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:43.041045 [ 17262 ] {} DDLWorker(rdb_test_rnaksl1p_2): Error on initialization of rdb_test_rnaksl1p_2: Code: 57. DB::Exception: Directory for table data store/b07/b0793e07-2e9e-4a1f-971a-0e0cb512abff/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:43.265550 [ 17252 ] {} DDLWorker(rdb_test_rnaksl1p_3): Error on initialization of rdb_test_rnaksl1p_3: Code: 57. DB::Exception: Directory for table data store/b07/b0793e07-2e9e-4a1f-971a-0e0cb512abff/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:48.059860 [ 17262 ] {} DDLWorker(rdb_test_rnaksl1p_2): Error on initialization of rdb_test_rnaksl1p_2: Code: 57. DB::Exception: Directory for table data store/b07/b0793e07-2e9e-4a1f-971a-0e0cb512abff/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1874: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188d00e0 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1491: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x00000000176de913 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1497: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x00000000176d7ae3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:181: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x00000000176fbc49 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x00000000176f8bf1 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x000000001829fde3 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000182c2fa6 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000182c2ec2 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000182c2d46 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x000000001829f6fa 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:ne190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x00000000176ec992 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010f15321 8. ./build_docker/./src/Common/AsyncLoader.cpp:882: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000010f16053 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x0000000010f12e5d 5. ./build_docker/./src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x0000000010f0fe96 6. ./build_docker/./src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x0000000010f0dd43 7. ./build_docker/./src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x0000000010f0e6f3 8. ./src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x0000000010eef074 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000188af59a 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5caa 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:31:49.187418 [ 46344 ] {517edceb-6aa9-4134-b9bd-b3b427b69aed} DatabaseReplicated (rdb_test_rnaksl1p_3): Database rdb_test_rnaksl1p_3 exists locally, but its replica does not exist in ZooKeeper (/test/test_rnaksl1p/rdb/replicas/s2|r1). Assuming it was dropped, will not try to start it up 2025.07.28 06:31:49.783366 [ 46344 ] {4a57c845-fc63-42b9-af3e-99808b9dc0cf} executeQuery: Code: 225. DB::Exception: Database is in readonly mode, because it cannot connect to ZooKeeper. (NO_ZOOKEEPER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56298) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: create table rdb_test_rnaksl1p_3.t2 as system.query_log), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1125: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000176d0775 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5cd7 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:49.785916 [ 46344 ] {} TCPHandler: Code: 225. DB::Exception: Database is in readonly mode, because it cannot connect to ZooKeeper. (NO_ZOOKEEPER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1125: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000176d0775 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5cd7 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:54.868449 [ 46344 ] {bc127a1d-4e7a-4bd6-a8b8-0dd95b32e8d3} DatabaseReplicated (rdb_test_rnaksl1p_2): Database rdb_test_rnaksl1p_2 exists locally, but its replica does not exist in ZooKeeper (/test/test_rnaksl1p/rdb/replicas/s1|r2). Assuming it was dropped, will not try to start it up 2025.07.28 06:31:55.373801 [ 46344 ] {5b27499c-a52e-4180-9077-96cba581efb2} executeQuery: Code: 225. DB::Exception: Database is in readonly mode, because it cannot connect to ZooKeeper. (NO_ZOOKEEPER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56340) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: create table rdb_test_rnaksl1p_2.t2 as system.query_log), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1125: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000176d0775 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5cd7 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:55.375944 [ 46344 ] {} TCPHandler: Code: 225. DB::Exception: Database is in readonly mode, because it cannot connect to ZooKeeper. (NO_ZOOKEEPER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1125: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000176d0775 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5cd7 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:56.760908 [ 46344 ] {fa60562d-2221-437f-8197-7a4900bad051} DatabaseReplicated (rdb_test_rnaksl1p): Database rdb_test_rnaksl1p exists locally, but its replica does not exist in ZooKeeper (/test/test_rnaksl1p/rdb/replicas/s1|r1). Assuming it was dropped, will not try to start it up 2025.07.28 06:31:57.350817 [ 46344 ] {abb9c2da-fa31-407b-8893-6ab817cace00} executeQuery: Code: 225. DB::Exception: Database is in readonly mode, because it cannot connect to ZooKeeper. (NO_ZOOKEEPER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59012) (comment: 02447_drop_database_replica.sh) (query 1, line 1) (in query: create table rdb_test_rnaksl1p.t2 as system.query_log), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1125: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000176d0775 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5cd7 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:31:57.352796 [ 46344 ] {} TCPHandler: Code: 225. DB::Exception: Database is in readonly mode, because it cannot connect to ZooKeeper. (NO_ZOOKEEPER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1125: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x00000000176d0775 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5cd7 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:32:14.237250 [ 42863 ] {3850f0b5-5c30-4dd8-b000-efa8a944d6d3} executeQuery: Code: 117. DB::Exception: Message has too many segments. Most likely, data was corrupted: (at row 1) : (in file/uri /var/lib/clickhouse/user_files/test_02402/overflow.capnp): While executing CapnProtoRowInputFormat: While executing File. (INCORRECT_DATA) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:50748) (comment: 02402_capnp_format_segments_overflow.sh) (query 1, line 1) (in query: SELECT * FROM file('test_02402/overflow.capnp', 'CapnProto') SETTINGS format_schema='test_02402/02402_overflow:CapnProto'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/Formats/Impl/CapnProtoRowInputFormat.cpp:38: DB::CapnProtoRowInputFormat::readMessagePrefix() @ 0x000000001be4b3fa 5. ./build_docker/./src/Processors/Formats/Impl/CapnProtoRowInputFormat.cpp:56: DB::CapnProtoRowInputFormat::readMessage() @ 0x000000001be4b48c 6. ./build_docker/./src/Processors/Formats/Impl/CapnProtoRowInputFormat.cpp:92: DB::CapnProtoRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001be4b7d4 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 15. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x000000001aac38e3 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 2025.07.28 06:32:14.241055 [ 42863 ] {} TCPHandler: Code: 117. DB::Exception: Message has too many segments. Most likely, data was corrupted: (at row 1) : (in file/uri /var/lib/clickhouse/user_files/test_02402/overflow.capnp): While executing CapnProtoRowInputFormat: While executing File. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Processors/Formats/Impl/CapnProtoRowInputFormat.cpp:38: DB::CapnProtoRowInputFormat::readMessagePrefix() @ 0x000000001be4b3fa 5. ./build_docker/./src/Processors/Formats/Impl/CapnProtoRowInputFormat.cpp:56: DB::CapnProtoRowInputFormat::readMessage() @ 0x000000001be4b48c 6. ./build_docker/./src/Processors/Formats/Impl/CapnProtoRowInputFormat.cpp:92: DB::CapnProtoRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001be4b7d4 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001bdbd4b0 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001bd2eb55 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 15. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x000000001aac38e3 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd105c0 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 25. __tsan_thread_start_func @ 0x0000000008756428 26. ? @ 0x00007fecd6763ac3 27. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:32:21.281020 [ 42863 ] {3f6c763e-b85f-47a4-a426-eb8dacd76269} executeQuery: Code: 36. DB::Exception: Empty messages are not supported: The table structure cannot be extracted from a Protobuf format file. You can specify the structure manually. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55090) (comment: 02327_capnproto_protobuf_empty_messages.sh) (query 1, line 1) (in query: desc file(data.pb) settings format_schema='test_02327/02327_schema:MessageWithEmpty'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Formats/ProtobufSerializer.cpp:3819: DB::(anonymous namespace)::getNameAndDataTypeFromFieldRecursive(google::protobuf::FieldDescriptor const*, bool, bool, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001c003589 5. ./build_docker/./src/Formats/ProtobufSerializer.cpp:3881: DB::protobufSchemaToCHSchema(google::protobuf::Descriptor const*, bool) @ 0x000000001bf9d05e 6. ./build_docker/./src/Processors/Formats/Impl/ProtobufRowInputFormat.cpp:138: DB::ProtobufSchemaReader::readSchema() @ 0x000000001c02b2b4 7. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:125: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcb84be 8. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 9. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 10. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 11. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013cbb194 12. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018e883a0 13. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000018e8713e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:32:21.283047 [ 42863 ] {} TCPHandler: Code: 36. DB::Exception: Empty messages are not supported: The table structure cannot be extracted from a Protobuf format file. You can specify the structure manually. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Formats/ProtobufSerializer.cpp:3819: DB::(anonymous namespace)::getNameAndDataTypeFromFieldRecursive(google::protobuf::FieldDescriptor const*, bool, bool, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001c003589 5. ./build_docker/./src/Formats/ProtobufSerializer.cpp:3881: DB::protobufSchemaToCHSchema(google::protobuf::Descriptor const*, bool) @ 0x000000001bf9d05e 6. ./build_docker/./src/Processors/Formats/Impl/ProtobufRowInputFormat.cpp:138: DB::ProtobufSchemaReader::readSchema() @ 0x000000001c02b2b4 7. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:125: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcb84be 8. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 9. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 10. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 11. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013cbb194 12. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018e883a0 13. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000018e8713e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:32:21.909113 [ 42863 ] {14326fee-48dd-4d82-a9aa-40b9c889992a} executeQuery: Code: 651. DB::Exception: Empty messages are not supported: The table structure cannot be extracted from a CapnProto format file. You can specify the structure manually. (CAPN_PROTO_BAD_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55092) (comment: 02327_capnproto_protobuf_empty_messages.sh) (query 1, line 1) (in query: desc file(data.capnp) settings format_schema='test_02327/02327_schema:MessageWithEmpty'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Formats/CapnProtoSchema.cpp:220: DB::(anonymous namespace)::getDataTypeFromCapnProtoType(capnp::Type const&, bool) @ 0x000000001be51ba8 5. ./build_docker/./src/Formats/CapnProtoSchema.cpp:285: DB::capnProtoSchemaToCHSchema(capnp::StructSchema const&, bool) @ 0x000000001be505be 6. ./build_docker/./src/Processors/Formats/Impl/CapnProtoRowInputFormat.cpp:132: DB::CapnProtoSchemaReader::readSchema() @ 0x000000001be4bcdb 7. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:125: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcb84be 8. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 9. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 10. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 11. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013cbb194 12. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018e883a0 13. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000018e8713e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:32:21.910590 [ 42863 ] {} TCPHandler: Code: 651. DB::Exception: Empty messages are not supported: The table structure cannot be extracted from a CapnProto format file. You can specify the structure manually. (CAPN_PROTO_BAD_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Formats/CapnProtoSchema.cpp:220: DB::(anonymous namespace)::getDataTypeFromCapnProtoType(capnp::Type const&, bool) @ 0x000000001be51ba8 5. ./build_docker/./src/Formats/CapnProtoSchema.cpp:285: DB::capnProtoSchemaToCHSchema(capnp::StructSchema const&, bool) @ 0x000000001be505be 6. ./build_docker/./src/Processors/Formats/Impl/CapnProtoRowInputFormat.cpp:132: DB::CapnProtoSchemaReader::readSchema() @ 0x000000001be4bcdb 7. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:125: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcb84be 8. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 9. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 10. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 11. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013cbb194 12. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000018e883a0 13. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000018e8713e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:32:22.545601 [ 42863 ] {71ba9aef-17df-4046-9f69-4c18b744647c} executeQuery: Code: 36. DB::Exception: Empty messages are not supported: The table structure cannot be extracted from a Protobuf format file. You can specify the structure manually. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55098) (comment: 02327_capnproto_protobuf_empty_messages.sh) (query 1, line 1) (in query: create table test_protobuf engine=File(Protobuf) settings format_schema='test_02327/02327_schema:MessageWithEmpty'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Formats/ProtobufSerializer.cpp:3819: DB::(anonymous namespace)::getNameAndDataTypeFromFieldRecursive(google::protobuf::FieldDescriptor const*, bool, bool, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001c003589 5. ./build_docker/./src/Formats/ProtobufSerializer.cpp:3881: DB::protobufSchemaToCHSchema(google::protobuf::Descriptor const*, bool) @ 0x000000001bf9d05e 6. ./build_docker/./src/Processors/Formats/Impl/ProtobufRowInputFormat.cpp:138: DB::ProtobufSchemaReader::readSchema() @ 0x000000001c02b2b4 7. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:125: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcb84be 8. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 9. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 10. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 11. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 12. ./build_docker/./src/Storages/StorageFile.cpp:1089: DB::StorageFile::StorageFile(String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabd453 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, DB::StorageFile::CommonArguments&) @ 0x000000001aadc0c3 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001aad388b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:32:22.547074 [ 42863 ] {} TCPHandler: Code: 36. DB::Exception: Empty messages are not supported: The table structure cannot be extracted from a Protobuf format file. You can specify the structure manually. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Formats/ProtobufSerializer.cpp:3819: DB::(anonymous namespace)::getNameAndDataTypeFromFieldRecursive(google::protobuf::FieldDescriptor const*, bool, bool, std::unordered_set, std::equal_to, std::allocator>&) @ 0x000000001c003589 5. ./build_docker/./src/Formats/ProtobufSerializer.cpp:3881: DB::protobufSchemaToCHSchema(google::protobuf::Descriptor const*, bool) @ 0x000000001bf9d05e 6. ./build_docker/./src/Processors/Formats/Impl/ProtobufRowInputFormat.cpp:138: DB::ProtobufSchemaReader::readSchema() @ 0x000000001c02b2b4 7. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:125: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcb84be 8. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 9. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 10. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 11. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 12. ./build_docker/./src/Storages/StorageFile.cpp:1089: DB::StorageFile::StorageFile(String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabd453 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, DB::StorageFile::CommonArguments&) @ 0x000000001aadc0c3 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001aad388b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:32:23.194958 [ 42863 ] {b19c9daf-85e4-4ddf-9113-f37374b5c73d} executeQuery: Code: 651. DB::Exception: Empty messages are not supported: The table structure cannot be extracted from a CapnProto format file. You can specify the structure manually. (CAPN_PROTO_BAD_TYPE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55114) (comment: 02327_capnproto_protobuf_empty_messages.sh) (query 1, line 1) (in query: create table test_capnp engine=File(CapnProto) settings format_schema='test_02327/02327_schema:MessageWithEmpty'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Formats/CapnProtoSchema.cpp:220: DB::(anonymous namespace)::getDataTypeFromCapnProtoType(capnp::Type const&, bool) @ 0x000000001be51ba8 5. ./build_docker/./src/Formats/CapnProtoSchema.cpp:285: DB::capnProtoSchemaToCHSchema(capnp::StructSchema const&, bool) @ 0x000000001be505be 6. ./build_docker/./src/Processors/Formats/Impl/CapnProtoRowInputFormat.cpp:132: DB::CapnProtoSchemaReader::readSchema() @ 0x000000001be4bcdb 7. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:125: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcb84be 8. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 9. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 10. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 11. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 12. ./build_docker/./src/Storages/StorageFile.cpp:1089: DB::StorageFile::StorageFile(String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabd453 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, DB::StorageFile::CommonArguments&) @ 0x000000001aadc0c3 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001aad388b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:32:23.196773 [ 42863 ] {} TCPHandler: Code: 651. DB::Exception: Empty messages are not supported: The table structure cannot be extracted from a CapnProto format file. You can specify the structure manually. (CAPN_PROTO_BAD_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Formats/CapnProtoSchema.cpp:220: DB::(anonymous namespace)::getDataTypeFromCapnProtoType(capnp::Type const&, bool) @ 0x000000001be51ba8 5. ./build_docker/./src/Formats/CapnProtoSchema.cpp:285: DB::capnProtoSchemaToCHSchema(capnp::StructSchema const&, bool) @ 0x000000001be505be 6. ./build_docker/./src/Processors/Formats/Impl/CapnProtoRowInputFormat.cpp:132: DB::CapnProtoSchemaReader::readSchema() @ 0x000000001be4bcdb 7. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:125: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcb84be 8. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001bcbe436 9. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9181 10. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001aab9967 11. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x000000001aabb015 12. ./build_docker/./src/Storages/StorageFile.cpp:1089: DB::StorageFile::StorageFile(String const&, DB::StorageFile::CommonArguments) @ 0x000000001aabd453 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, DB::StorageFile::CommonArguments&) @ 0x000000001aadc0c3 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001aad388b 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:32:36.324629 [ 42863 ] {0ce703d3-438e-4367-8404-a2287cdd2994} executeQuery: Code: 36. DB::Exception: There is no cache by name: ff. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33798) (comment: 02286_drop_filesystem_cache.sh) (query 1, line 1) (in query: SYSTEM DROP FILESYSTEM CACHE 'ff';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/Cache/FileCacheFactory.cpp:148: DB::FileCacheFactory::getByName(String const&) @ 0x0000000018eec5aa 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:458: DB::InterpreterSystemQuery::execute() @ 0x0000000018e570a6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:32:36.325590 [ 42863 ] {} TCPHandler: Code: 36. DB::Exception: There is no cache by name: ff. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/Cache/FileCacheFactory.cpp:148: DB::FileCacheFactory::getByName(String const&) @ 0x0000000018eec5aa 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:458: DB::InterpreterSystemQuery::execute() @ 0x0000000018e570a6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:32:46.977337 [ 42863 ] {bb6945c7-b1fd-4613-8500-c67e0bf83833} executeQuery: Code: 36. DB::Exception: There is no cache by name: ff. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:51856) (comment: 02286_drop_filesystem_cache.sh) (query 1, line 1) (in query: SYSTEM DROP FILESYSTEM CACHE 'ff';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/Cache/FileCacheFactory.cpp:148: DB::FileCacheFactory::getByName(String const&) @ 0x0000000018eec5aa 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:458: DB::InterpreterSystemQuery::execute() @ 0x0000000018e570a6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:32:46.978158 [ 42863 ] {} TCPHandler: Code: 36. DB::Exception: There is no cache by name: ff. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/Cache/FileCacheFactory.cpp:148: DB::FileCacheFactory::getByName(String const&) @ 0x0000000018eec5aa 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:458: DB::InterpreterSystemQuery::execute() @ 0x0000000018e570a6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:33:07.810941 [ 42863 ] {2ebfc5b8-f86a-4e4e-af67-e307edb169e7} executeQuery: Code: 36. DB::Exception: There is no cache by name: ff. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49772) (comment: 02286_drop_filesystem_cache.sh) (query 1, line 1) (in query: SYSTEM DROP FILESYSTEM CACHE 'ff';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/Cache/FileCacheFactory.cpp:148: DB::FileCacheFactory::getByName(String const&) @ 0x0000000018eec5aa 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:458: DB::InterpreterSystemQuery::execute() @ 0x0000000018e570a6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:33:07.812107 [ 42863 ] {} TCPHandler: Code: 36. DB::Exception: There is no cache by name: ff. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Interpreters/Cache/FileCacheFactory.cpp:148: DB::FileCacheFactory::getByName(String const&) @ 0x0000000018eec5aa 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:458: DB::InterpreterSystemQuery::execute() @ 0x0000000018e570a6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:33:30.361654 [ 42863 ] {89714432-845a-409a-9c3a-0045566d3ab9} DNSResolver: Cannot resolve host (ThisHostNameDoesNotExistSoItShouldFail), error 0: Host not found. 2025.07.28 06:33:30.363035 [ 42863 ] {89714432-845a-409a-9c3a-0045566d3ab9} Cluster: Code: 198. DB::NetException: Not found address of host: ThisHostNameDoesNotExistSoItShouldFail. (DNS_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000010aead79 3. ./build_docker/./src/Common/DNSResolver.cpp:113: DB::(anonymous namespace)::hostByName(String const&) @ 0x0000000010ae66e3 4. ./build_docker/./src/Common/DNSResolver.cpp:138: DB::DNSResolver::getResolvedIPAdressessWithFiltering(String const&) @ 0x0000000010ae4cb3 5. ./build_docker/./src/Common/DNSResolver.cpp:256: DB::DNSResolver::resolveIPAddressWithCache(String const&) @ 0x0000000010ae5299 6. ./build_docker/./src/Common/DNSResolver.cpp:305: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x0000000010ae60df 7. ./build_docker/./src/Interpreters/Cluster.cpp:82: DB::Cluster::Address::getResolvedAddress() const @ 0x0000000018153381 8. ./build_docker/./src/Interpreters/Cluster.cpp:95: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x0000000018155947 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Address* std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x0000000018167be0 10. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001815fd8a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000013c8d9d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8aad6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:33:38.374519 [ 42863 ] {89714432-845a-409a-9c3a-0045566d3ab9} DNSResolver: Cannot resolve host (ThisHostNameDoesNotExistSoItShouldFail), error 0: Host not found. 2025.07.28 06:33:46.384360 [ 557 ] {} DNSResolver: Cannot resolve host (ThisHostNameDoesNotExistSoItShouldFail), error 0: Host not found. 2025.07.28 06:33:54.394546 [ 42863 ] {89714432-845a-409a-9c3a-0045566d3ab9} DNSResolver: Cannot resolve host (ThisHostNameDoesNotExistSoItShouldFail), error 0: Host not found. 2025.07.28 06:34:02.404812 [ 42863 ] {89714432-845a-409a-9c3a-0045566d3ab9} DNSResolver: Cannot resolve host (ThisHostNameDoesNotExistSoItShouldFail), error 0: Host not found. 2025.07.28 06:34:02.509311 [ 42863 ] {89714432-845a-409a-9c3a-0045566d3ab9} executeQuery: Code: 519. DB::NetException: All attempts to get table structure failed. Log: Code: 279. DB::NetException: All connection tries failed. Log: Code: 198. DB::NetException: Not found address of host: ThisHostNameDoesNotExistSoItShouldFail: (ThisHostNameDoesNotExistSoItShouldFail:9000). (DNS_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 198. DB::NetException: Not found address of host: ThisHostNameDoesNotExistSoItShouldFail: (ThisHostNameDoesNotExistSoItShouldFail:9000). (DNS_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 198. DB::NetException: Not found address of host: ThisHostNameDoesNotExistSoItShouldFail: (ThisHostNameDoesNotExistSoItShouldFail:9000). (DNS_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) . (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) . (NO_REMOTE_SHARD_AVAILABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:35312) (comment: 02265_test_dns_profile_events.sh) (query 1, line 1) (in query: SELECT * FROM remote('ThisHostNameDoesNotExistSoItShouldFail', system, one)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x000000001aecfdf6 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013c8fca6 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013c8f349 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 7. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:34:02.511214 [ 42863 ] {} TCPHandler: Code: 519. DB::NetException: All attempts to get table structure failed. Log: Code: 279. DB::NetException: All connection tries failed. Log: Code: 198. DB::NetException: Not found address of host: ThisHostNameDoesNotExistSoItShouldFail: (ThisHostNameDoesNotExistSoItShouldFail:9000). (DNS_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 198. DB::NetException: Not found address of host: ThisHostNameDoesNotExistSoItShouldFail: (ThisHostNameDoesNotExistSoItShouldFail:9000). (DNS_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 198. DB::NetException: Not found address of host: ThisHostNameDoesNotExistSoItShouldFail: (ThisHostNameDoesNotExistSoItShouldFail:9000). (DNS_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) . (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) . (NO_REMOTE_SHARD_AVAILABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x000000001aecfdf6 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013c8fca6 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013c8f349 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 7. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:34:11.938628 [ 42863 ] {f94dc011-73ca-41dd-9f2f-8259aba390b4} DNSResolver: Cannot resolve host (ThisHostNameDoesNotExistSoItShouldFail2), error 0: Host not found. 2025.07.28 06:34:11.939352 [ 42863 ] {f94dc011-73ca-41dd-9f2f-8259aba390b4} Cluster: Code: 198. DB::NetException: Not found address of host: ThisHostNameDoesNotExistSoItShouldFail2. (DNS_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String const&) @ 0x0000000010aead79 3. ./build_docker/./src/Common/DNSResolver.cpp:113: DB::(anonymous namespace)::hostByName(String const&) @ 0x0000000010ae66e3 4. ./build_docker/./src/Common/DNSResolver.cpp:138: DB::DNSResolver::getResolvedIPAdressessWithFiltering(String const&) @ 0x0000000010ae4cb3 5. ./build_docker/./src/Common/DNSResolver.cpp:256: DB::DNSResolver::resolveIPAddressWithCache(String const&) @ 0x0000000010ae5299 6. ./build_docker/./src/Common/DNSResolver.cpp:305: DB::DNSResolver::resolveAddress(String const&, unsigned short) @ 0x0000000010ae60df 7. ./build_docker/./src/Interpreters/Cluster.cpp:82: DB::Cluster::Address::getResolvedAddress() const @ 0x0000000018153381 8. ./build_docker/./src/Interpreters/Cluster.cpp:95: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x0000000018155947 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Address* std::vector>::__emplace_back_slow_path(DB::DatabaseReplicaInfo&&, DB::ClusterConnectionParameters const&, unsigned int&, unsigned long&&) @ 0x0000000018167be0 10. ./contrib/llvm-project/libcxx/include/vector:1558: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000001815fd8a 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000013c8d9d0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8aad6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:34:17.426219 [ 572 ] {} DNSResolver: Cannot resolve host (ThisHostNameDoesNotExistSoItShouldFail), error 0: Host not found. 2025.07.28 06:34:19.950416 [ 42863 ] {f94dc011-73ca-41dd-9f2f-8259aba390b4} DNSResolver: Cannot resolve host (ThisHostNameDoesNotExistSoItShouldFail2), error 0: Host not found. 2025.07.28 06:34:27.958076 [ 42863 ] {f94dc011-73ca-41dd-9f2f-8259aba390b4} DNSResolver: Cannot resolve host (ThisHostNameDoesNotExistSoItShouldFail2), error 0: Host not found. 2025.07.28 06:34:35.967227 [ 572 ] {} DNSResolver: Cannot resolve host (ThisHostNameDoesNotExistSoItShouldFail2), error 0: Host not found. 2025.07.28 06:34:43.976928 [ 42863 ] {f94dc011-73ca-41dd-9f2f-8259aba390b4} DNSResolver: Cannot resolve host (ThisHostNameDoesNotExistSoItShouldFail2), error 0: Host not found. 2025.07.28 06:34:43.980344 [ 42863 ] {f94dc011-73ca-41dd-9f2f-8259aba390b4} executeQuery: Code: 519. DB::NetException: All attempts to get table structure failed. Log: Code: 279. DB::NetException: All connection tries failed. Log: Code: 198. DB::NetException: Not found address of host: ThisHostNameDoesNotExistSoItShouldFail2: (ThisHostNameDoesNotExistSoItShouldFail2:9000). (DNS_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 198. DB::NetException: Not found address of host: ThisHostNameDoesNotExistSoItShouldFail2: (ThisHostNameDoesNotExistSoItShouldFail2:9000). (DNS_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 198. DB::NetException: Not found address of host: ThisHostNameDoesNotExistSoItShouldFail2: (ThisHostNameDoesNotExistSoItShouldFail2:9000). (DNS_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) . (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) . (NO_REMOTE_SHARD_AVAILABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60892) (comment: 02265_test_dns_profile_events.sh) (query 1, line 1) (in query: SELECT * FROM remote('ThisHostNameDoesNotExistSoItShouldFail2', system, one)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x000000001aecfdf6 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013c8fca6 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013c8f349 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 7. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:34:43.984497 [ 42863 ] {} TCPHandler: Code: 519. DB::NetException: All attempts to get table structure failed. Log: Code: 279. DB::NetException: All connection tries failed. Log: Code: 198. DB::NetException: Not found address of host: ThisHostNameDoesNotExistSoItShouldFail2: (ThisHostNameDoesNotExistSoItShouldFail2:9000). (DNS_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 198. DB::NetException: Not found address of host: ThisHostNameDoesNotExistSoItShouldFail2: (ThisHostNameDoesNotExistSoItShouldFail2:9000). (DNS_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) Code: 198. DB::NetException: Not found address of host: ThisHostNameDoesNotExistSoItShouldFail2: (ThisHostNameDoesNotExistSoItShouldFail2:9000). (DNS_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) . (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) . (NO_REMOTE_SHARD_AVAILABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001aed1e79 3. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x000000001aecfdf6 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000013c8fca6 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013c8f349 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 7. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 28. __tsan_thread_start_func @ 0x0000000008756428 29. ? @ 0x00007fecd6763ac3 30. ? @ 0x00007fecd67f5850 2025.07.28 06:34:45.563026 [ 42836 ] {9fb690d2-9071-47f4-87bc-90febc039a6d} Context: Server has databases (for example `02265_ordinary_db`) with Ordinary engine, which was deprecated. To convert this database to the new Atomic engine, create a flag /var/lib/clickhouse/flags/convert_ordinary_to_atomic and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' && sudo chmod 666 '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' 2025.07.28 06:35:02.382040 [ 42836 ] {c9f03811-5c42-4e21-8f22-5c9c4d165033} executeQuery: Code: 497. DB::Exception: user_test_02184: Not enough privileges. To execute this query, it's necessary to have the grant TABLE ENGINE ON URL. (ACCESS_DENIED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57566) (comment: 02184_table_engine_access.sh) (query 1, line 1) (in query: CREATE TABLE t AS url), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d06090 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d0468e 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x0000000016d03ad1 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>) const @ 0x0000000016ccea90 8. ./src/Access/ContextAccess.h:255: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>) const @ 0x000000001819c3c9 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:765: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b6e13 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:35:02.383587 [ 42836 ] {} TCPHandler: Code: 497. DB::Exception: user_test_02184: Not enough privileges. To execute this query, it's necessary to have the grant TABLE ENGINE ON URL. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Access/ContextAccess.cpp:613: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000016d06090 5. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000016d0468e 6. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x0000000016d03ad1 7. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>) const @ 0x0000000016ccea90 8. ./src/Access/ContextAccess.h:255: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>) const @ 0x000000001819c3c9 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:765: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000188b6e13 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c5253 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 21. __tsan_thread_start_func @ 0x0000000008756428 22. ? @ 0x00007fecd6763ac3 23. ? @ 0x00007fecd67f5850 2025.07.28 06:35:31.571019 [ 1027 ] {8614bb8c-142b-4259-9bdc-e7de7017a42b::all_1_6_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x000000001b28e0f6 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x000000001b2a2b55 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x000000001b2a2869 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001b2a02ce 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x000000001b2a9457 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000001b8041df 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000001b2d9a5f 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000001b2da4f1 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2dc862 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:37.507372 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: invalid_session_log_test_xml_user: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:37.507654 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: invalid_session_log_test_xml_user: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:37.649301 [ 42836 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_xml_user: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:37.676279 [ 42836 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_xml_user: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:38.746789 [ 2061 ] {} MYSQL-Session-b18148c0-3bef-4fcb-a7fa-99ba910694cd: b18148c0-3bef-4fcb-a7fa-99ba910694cd Authentication failed with error: There is no user `invalid_session_log_test_xml_user` in user directories 2025.07.28 06:35:38.747166 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_xml_user failed. 2025.07.28 06:35:38.747504 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_xml_user` in user directories 2025.07.28 06:35:38.748999 [ 42836 ] {447e969e-0c1d-4086-8043-e28b8d86ba80} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_xml_user): mysqlxx::ConnectionFailed 2025.07.28 06:35:38.749443 [ 42836 ] {447e969e-0c1d-4086-8043-e28b8d86ba80} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_xml_user failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_xml_user` in user directories ((nullptr):9004) 2025.07.28 06:35:38.749596 [ 42836 ] {447e969e-0c1d-4086-8043-e28b8d86ba80} Application: Connection to mysql failed 1 times 2025.07.28 06:35:38.771602 [ 2061 ] {} MYSQL-Session-c57a5168-1df1-4d2d-918e-7b9c5963f8c5: c57a5168-1df1-4d2d-918e-7b9c5963f8c5 Authentication failed with error: There is no user `invalid_session_log_test_xml_user` in user directories 2025.07.28 06:35:38.771842 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_xml_user failed. 2025.07.28 06:35:38.772153 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_xml_user` in user directories 2025.07.28 06:35:38.773151 [ 42836 ] {447e969e-0c1d-4086-8043-e28b8d86ba80} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_xml_user): mysqlxx::ConnectionFailed 2025.07.28 06:35:38.773490 [ 42836 ] {447e969e-0c1d-4086-8043-e28b8d86ba80} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_xml_user failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_xml_user` in user directories ((nullptr):9004) 2025.07.28 06:35:38.773629 [ 42836 ] {447e969e-0c1d-4086-8043-e28b8d86ba80} Application: Connection to mysql failed 2 times 2025.07.28 06:35:38.801374 [ 2061 ] {} MYSQL-Session-6a4965dc-a979-44f5-985f-13adc68c53af: 6a4965dc-a979-44f5-985f-13adc68c53af Authentication failed with error: There is no user `invalid_session_log_test_xml_user` in user directories 2025.07.28 06:35:38.801791 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_xml_user failed. 2025.07.28 06:35:38.802346 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_xml_user` in user directories 2025.07.28 06:35:38.803279 [ 42836 ] {447e969e-0c1d-4086-8043-e28b8d86ba80} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_xml_user): mysqlxx::ConnectionFailed 2025.07.28 06:35:38.803701 [ 42836 ] {447e969e-0c1d-4086-8043-e28b8d86ba80} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_xml_user failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_xml_user` in user directories ((nullptr):9004) 2025.07.28 06:35:38.803895 [ 42836 ] {447e969e-0c1d-4086-8043-e28b8d86ba80} Application: Connection to mysql failed 3 times 2025.07.28 06:35:38.936143 [ 42836 ] {447e969e-0c1d-4086-8043-e28b8d86ba80} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_xml_user, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_xml_user` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52818) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'invalid_session_log_test_xml_user', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:35:38.937494 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_xml_user, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_xml_user` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:35:39.393164 [ 42861 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:35:39.394466 [ 45958 ] {} POSTGRESQL-Session-33ff5dfe-10da-4989-a838-2e951ea212a4: 33ff5dfe-10da-4989-a838-2e951ea212a4 Authentication failed with error: There is no user `invalid_session_log_test_xml_user` in user directories 2025.07.28 06:35:39.394840 [ 45958 ] {} PostgreSQLHandler: DB::Exception: There is no user `invalid_session_log_test_xml_user` in user directories 2025.07.28 06:35:39.397953 [ 42836 ] {44de58f2-99fe-4ba6-b8cb-3b1018aefb64} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:35:39.401213 [ 45958 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:35:39.402101 [ 42861 ] {} POSTGRESQL-Session-7c21f729-db90-48d2-aa20-7b8b75b22955: 7c21f729-db90-48d2-aa20-7b8b75b22955 Authentication failed with error: There is no user `invalid_session_log_test_xml_user` in user directories 2025.07.28 06:35:39.402314 [ 42861 ] {} PostgreSQLHandler: DB::Exception: There is no user `invalid_session_log_test_xml_user` in user directories 2025.07.28 06:35:39.402500 [ 42836 ] {44de58f2-99fe-4ba6-b8cb-3b1018aefb64} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:35:39.498057 [ 42836 ] {44de58f2-99fe-4ba6-b8cb-3b1018aefb64} executeQuery: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52832) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM postgresql('localhost:9005', 'system', 'one', 'invalid_session_log_test_xml_user', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:35:39.499236 [ 42836 ] {} TCPHandler: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:35:41.782316 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:41.782566 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:41.834721 [ 42836 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:41.862034 [ 42836 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:42.904492 [ 2061 ] {} MYSQL-Session-140c3394-8e14-4263-965a-7028c5250b51: 140c3394-8e14-4263-965a-7028c5250b51 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:42.904755 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles failed. 2025.07.28 06:35:42.905019 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:42.905725 [ 42836 ] {5b52d4f4-7f58-48be-a145-ed5e977b2e50} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:35:42.906021 [ 42836 ] {5b52d4f4-7f58-48be-a145-ed5e977b2e50} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:35:42.906124 [ 42836 ] {5b52d4f4-7f58-48be-a145-ed5e977b2e50} Application: Connection to mysql failed 1 times 2025.07.28 06:35:42.922716 [ 2061 ] {} MYSQL-Session-0080f16d-f2c1-4b7b-88e9-3cc8a80eb4cb: 0080f16d-f2c1-4b7b-88e9-3cc8a80eb4cb Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:42.922939 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles failed. 2025.07.28 06:35:42.923164 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:42.923758 [ 42836 ] {5b52d4f4-7f58-48be-a145-ed5e977b2e50} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:35:42.924051 [ 42836 ] {5b52d4f4-7f58-48be-a145-ed5e977b2e50} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:35:42.924145 [ 42836 ] {5b52d4f4-7f58-48be-a145-ed5e977b2e50} Application: Connection to mysql failed 2 times 2025.07.28 06:35:42.939088 [ 2061 ] {} MYSQL-Session-eb7ce946-b94c-4cf3-8f13-e57e17d72b4d: eb7ce946-b94c-4cf3-8f13-e57e17d72b4d Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:42.939259 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles failed. 2025.07.28 06:35:42.939500 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:42.939891 [ 42836 ] {5b52d4f4-7f58-48be-a145-ed5e977b2e50} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:35:42.940078 [ 42836 ] {5b52d4f4-7f58-48be-a145-ed5e977b2e50} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:35:42.940224 [ 42836 ] {5b52d4f4-7f58-48be-a145-ed5e977b2e50} Application: Connection to mysql failed 3 times 2025.07.28 06:35:42.941521 [ 42836 ] {5b52d4f4-7f58-48be-a145-ed5e977b2e50} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52888) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:35:42.942701 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:35:43.378140 [ 42861 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:35:43.378959 [ 45958 ] {} POSTGRESQL-Session-a7c4ddbc-18fe-40ae-a778-fe40d0672fc5: a7c4ddbc-18fe-40ae-a778-fe40d0672fc5 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:43.379219 [ 45958 ] {} PostgreSQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:43.379441 [ 42836 ] {33512c72-26ab-41b4-bfdc-78cf760e227f} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:35:43.382897 [ 45958 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:35:43.384546 [ 42861 ] {} POSTGRESQL-Session-a9bf47bf-e666-4bb2-bb0c-d4e13c38324b: a9bf47bf-e666-4bb2-bb0c-d4e13c38324b Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:43.384983 [ 42861 ] {} PostgreSQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:43.385127 [ 42836 ] {33512c72-26ab-41b4-bfdc-78cf760e227f} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:35:43.386348 [ 42836 ] {33512c72-26ab-41b4-bfdc-78cf760e227f} executeQuery: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52896) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM postgresql('localhost:9005', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_no_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:35:43.387314 [ 42836 ] {} TCPHandler: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:35:45.642164 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:45.642429 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:45.696815 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:45.724323 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:46.763784 [ 2061 ] {} MYSQL-Session-43ff91e0-ad25-4517-bce7-6c4402fab486: 43ff91e0-ad25-4517-bce7-6c4402fab486 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles` in user directories 2025.07.28 06:35:46.764044 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles failed. 2025.07.28 06:35:46.764307 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles` in user directories 2025.07.28 06:35:46.765060 [ 42836 ] {a345b9bf-289d-4d6b-9675-9308a77f3b6f} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:35:46.765355 [ 42836 ] {a345b9bf-289d-4d6b-9675-9308a77f3b6f} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:35:46.765536 [ 42836 ] {a345b9bf-289d-4d6b-9675-9308a77f3b6f} Application: Connection to mysql failed 1 times 2025.07.28 06:35:46.784465 [ 2061 ] {} MYSQL-Session-c6ba8008-592b-4e8f-9596-e3c4414031df: c6ba8008-592b-4e8f-9596-e3c4414031df Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles` in user directories 2025.07.28 06:35:46.784697 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles failed. 2025.07.28 06:35:46.785061 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles` in user directories 2025.07.28 06:35:46.785676 [ 42836 ] {a345b9bf-289d-4d6b-9675-9308a77f3b6f} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:35:46.786103 [ 42836 ] {a345b9bf-289d-4d6b-9675-9308a77f3b6f} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:35:46.786253 [ 42836 ] {a345b9bf-289d-4d6b-9675-9308a77f3b6f} Application: Connection to mysql failed 2 times 2025.07.28 06:35:46.807016 [ 2061 ] {} MYSQL-Session-5eebac11-1511-4aec-b9ee-fcaba93ee16f: 5eebac11-1511-4aec-b9ee-fcaba93ee16f Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles` in user directories 2025.07.28 06:35:46.807298 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles failed. 2025.07.28 06:35:46.807688 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles` in user directories 2025.07.28 06:35:46.808335 [ 42836 ] {a345b9bf-289d-4d6b-9675-9308a77f3b6f} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:35:46.808662 [ 42836 ] {a345b9bf-289d-4d6b-9675-9308a77f3b6f} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:35:46.808805 [ 42836 ] {a345b9bf-289d-4d6b-9675-9308a77f3b6f} Application: Connection to mysql failed 3 times 2025.07.28 06:35:46.811030 [ 42836 ] {a345b9bf-289d-4d6b-9675-9308a77f3b6f} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:52972) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:35:46.812736 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:35:47.236045 [ 42861 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:35:47.237253 [ 45958 ] {} POSTGRESQL-Session-b6a77c76-3cbd-4752-bea2-a31d764dd9f4: b6a77c76-3cbd-4752-bea2-a31d764dd9f4 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles` in user directories 2025.07.28 06:35:47.237613 [ 45958 ] {} PostgreSQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles` in user directories 2025.07.28 06:35:47.237981 [ 42836 ] {132e0343-fe1f-4197-ad5c-2bb301a408ce} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:35:47.243919 [ 45958 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:35:47.244713 [ 42861 ] {} POSTGRESQL-Session-69832e08-0df4-4ab7-b1e1-61db5bc81262: 69832e08-0df4-4ab7-b1e1-61db5bc81262 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles` in user directories 2025.07.28 06:35:47.244947 [ 42861 ] {} PostgreSQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles` in user directories 2025.07.28 06:35:47.245513 [ 42836 ] {132e0343-fe1f-4197-ad5c-2bb301a408ce} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:35:47.247554 [ 42836 ] {132e0343-fe1f-4197-ad5c-2bb301a408ce} executeQuery: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34288) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM postgresql('localhost:9005', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:35:47.249285 [ 42836 ] {} TCPHandler: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:35:49.603126 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:49.603388 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:49.660647 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:49.688636 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:50.801971 [ 2061 ] {} MYSQL-Session-f1bc61d7-7bd1-4d22-bace-bf1bf6a30c35: f1bc61d7-7bd1-4d22-bace-bf1bf6a30c35 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles` in user directories 2025.07.28 06:35:50.802222 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles failed. 2025.07.28 06:35:50.802480 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles` in user directories 2025.07.28 06:35:50.803703 [ 42836 ] {32749324-fc2b-4978-bffd-6e2f3b2f0b1d} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:35:50.804338 [ 42836 ] {32749324-fc2b-4978-bffd-6e2f3b2f0b1d} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles` in user directories ((nullptr):9004) 2025.07.28 06:35:50.804575 [ 42836 ] {32749324-fc2b-4978-bffd-6e2f3b2f0b1d} Application: Connection to mysql failed 1 times 2025.07.28 06:35:50.824539 [ 2061 ] {} MYSQL-Session-de459069-69bf-4169-8fb4-34d77ddb44fb: de459069-69bf-4169-8fb4-34d77ddb44fb Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles` in user directories 2025.07.28 06:35:50.824681 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles failed. 2025.07.28 06:35:50.824857 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles` in user directories 2025.07.28 06:35:50.825636 [ 42836 ] {32749324-fc2b-4978-bffd-6e2f3b2f0b1d} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:35:50.825975 [ 42836 ] {32749324-fc2b-4978-bffd-6e2f3b2f0b1d} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles` in user directories ((nullptr):9004) 2025.07.28 06:35:50.826110 [ 42836 ] {32749324-fc2b-4978-bffd-6e2f3b2f0b1d} Application: Connection to mysql failed 2 times 2025.07.28 06:35:50.843473 [ 2061 ] {} MYSQL-Session-5a50cf8d-5f59-45a3-8193-0884d1eb799f: 5a50cf8d-5f59-45a3-8193-0884d1eb799f Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles` in user directories 2025.07.28 06:35:50.843652 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles failed. 2025.07.28 06:35:50.843856 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles` in user directories 2025.07.28 06:35:50.844692 [ 42836 ] {32749324-fc2b-4978-bffd-6e2f3b2f0b1d} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:35:50.845003 [ 42836 ] {32749324-fc2b-4978-bffd-6e2f3b2f0b1d} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles` in user directories ((nullptr):9004) 2025.07.28 06:35:50.845111 [ 42836 ] {32749324-fc2b-4978-bffd-6e2f3b2f0b1d} Application: Connection to mysql failed 3 times 2025.07.28 06:35:50.848049 [ 42836 ] {32749324-fc2b-4978-bffd-6e2f3b2f0b1d} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34350) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:35:50.850100 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:35:51.317743 [ 42861 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:35:51.318884 [ 45958 ] {} POSTGRESQL-Session-2f9d16d7-7273-44f8-b7ba-08919149a97c: 2f9d16d7-7273-44f8-b7ba-08919149a97c Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles` in user directories 2025.07.28 06:35:51.319204 [ 45958 ] {} PostgreSQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles` in user directories 2025.07.28 06:35:51.319509 [ 42836 ] {2f7f7e57-4879-4c0a-9903-3927da690f6e} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:35:51.322723 [ 45958 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:35:51.323496 [ 42861 ] {} POSTGRESQL-Session-9235fb4b-4119-4188-b92d-3bc7e39bba23: 9235fb4b-4119-4188-b92d-3bc7e39bba23 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles` in user directories 2025.07.28 06:35:51.323741 [ 42861 ] {} PostgreSQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles` in user directories 2025.07.28 06:35:51.323932 [ 42836 ] {2f7f7e57-4879-4c0a-9903-3927da690f6e} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:35:51.325280 [ 42836 ] {2f7f7e57-4879-4c0a-9903-3927da690f6e} executeQuery: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34362) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM postgresql('localhost:9005', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_no_password_two_profiles_two_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:35:51.326419 [ 42836 ] {} TCPHandler: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:35:53.686379 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:53.686634 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:54.076520 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:54.076758 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:54.137281 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:54.146245 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:54.175813 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:54.184812 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:55.281437 [ 2061 ] {} MYSQL-Session-fb94c949-5007-4b64-8e55-9b633d56112f: fb94c949-5007-4b64-8e55-9b633d56112f Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:55.281602 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles failed. 2025.07.28 06:35:55.281765 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:55.282388 [ 42836 ] {654687fd-fba0-4b22-b872-8dd4829ffe25} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:35:55.282606 [ 42836 ] {654687fd-fba0-4b22-b872-8dd4829ffe25} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:35:55.282689 [ 42836 ] {654687fd-fba0-4b22-b872-8dd4829ffe25} Application: Connection to mysql failed 1 times 2025.07.28 06:35:55.295399 [ 2061 ] {} MYSQL-Session-2cc37f8e-87e9-46db-b48f-d75a126b5ee4: 2cc37f8e-87e9-46db-b48f-d75a126b5ee4 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:55.295567 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles failed. 2025.07.28 06:35:55.295726 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:55.296141 [ 42836 ] {654687fd-fba0-4b22-b872-8dd4829ffe25} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:35:55.296355 [ 42836 ] {654687fd-fba0-4b22-b872-8dd4829ffe25} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:35:55.296462 [ 42836 ] {654687fd-fba0-4b22-b872-8dd4829ffe25} Application: Connection to mysql failed 2 times 2025.07.28 06:35:55.309397 [ 2061 ] {} MYSQL-Session-b750b331-03c9-4c70-8725-18e6ca5a9cbe: b750b331-03c9-4c70-8725-18e6ca5a9cbe Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:55.309549 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles failed. 2025.07.28 06:35:55.309702 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:55.310157 [ 42836 ] {654687fd-fba0-4b22-b872-8dd4829ffe25} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:35:55.310378 [ 42836 ] {654687fd-fba0-4b22-b872-8dd4829ffe25} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:35:55.310449 [ 42836 ] {654687fd-fba0-4b22-b872-8dd4829ffe25} Application: Connection to mysql failed 3 times 2025.07.28 06:35:55.311824 [ 42836 ] {654687fd-fba0-4b22-b872-8dd4829ffe25} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34434) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:35:55.312914 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:35:55.853087 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles failed. 2025.07.28 06:35:55.853275 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:35:55.854132 [ 42836 ] {2a502d5d-cf26-4372-97bd-4dfe9ce91fc8} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:35:55.854427 [ 42836 ] {2a502d5d-cf26-4372-97bd-4dfe9ce91fc8} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:35:55.854526 [ 42836 ] {2a502d5d-cf26-4372-97bd-4dfe9ce91fc8} Application: Connection to mysql failed 1 times 2025.07.28 06:35:55.868622 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles failed. 2025.07.28 06:35:55.868750 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:35:55.869369 [ 42836 ] {2a502d5d-cf26-4372-97bd-4dfe9ce91fc8} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:35:55.869588 [ 42836 ] {2a502d5d-cf26-4372-97bd-4dfe9ce91fc8} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:35:55.869679 [ 42836 ] {2a502d5d-cf26-4372-97bd-4dfe9ce91fc8} Application: Connection to mysql failed 2 times 2025.07.28 06:35:55.882660 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles failed. 2025.07.28 06:35:55.882817 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:35:55.883333 [ 42836 ] {2a502d5d-cf26-4372-97bd-4dfe9ce91fc8} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:35:55.883589 [ 42836 ] {2a502d5d-cf26-4372-97bd-4dfe9ce91fc8} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:35:55.883664 [ 42836 ] {2a502d5d-cf26-4372-97bd-4dfe9ce91fc8} Application: Connection to mysql failed 3 times 2025.07.28 06:35:55.885106 [ 42836 ] {2a502d5d-cf26-4372-97bd-4dfe9ce91fc8} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34448) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:35:55.886250 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:35:56.348574 [ 42861 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:35:56.349417 [ 45958 ] {} POSTGRESQL-Session-c1df5fa5-0eed-4212-8efe-6a444bcf1a44: c1df5fa5-0eed-4212-8efe-6a444bcf1a44 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:56.349659 [ 45958 ] {} PostgreSQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:56.349922 [ 42836 ] {4441ac54-3c18-4abc-b688-46876785b4f1} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:35:56.353286 [ 45958 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:35:56.354693 [ 42861 ] {} POSTGRESQL-Session-064327e7-1e28-471a-a84e-1f7738da696b: 064327e7-1e28-471a-a84e-1f7738da696b Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:56.355241 [ 42861 ] {} PostgreSQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles` in user directories 2025.07.28 06:35:56.355325 [ 42836 ] {4441ac54-3c18-4abc-b688-46876785b4f1} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:35:56.356697 [ 42836 ] {4441ac54-3c18-4abc-b688-46876785b4f1} executeQuery: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34462) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM postgresql('localhost:9005', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:35:56.357820 [ 42836 ] {} TCPHandler: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:35:56.811134 [ 42861 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:35:56.891168 [ 45958 ] {} PostgreSQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:35:56.891523 [ 42836 ] {7a8e3355-6e94-447b-b590-c796268806e2} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:35:56.895275 [ 45958 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:35:56.898153 [ 42861 ] {} PostgreSQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:35:56.898319 [ 42836 ] {7a8e3355-6e94-447b-b590-c796268806e2} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:35:56.899961 [ 42836 ] {7a8e3355-6e94-447b-b590-c796268806e2} executeQuery: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:34478) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM postgresql('localhost:9005', 'system', 'one', 'session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_no_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:35:56.901187 [ 42836 ] {} TCPHandler: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:35:59.116707 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:59.116945 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:59.508511 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:59.508757 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:59.563068 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:59.571639 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:59.600447 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:35:59.609424 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:00.623495 [ 2061 ] {} MYSQL-Session-6e927b5b-b40c-4b9f-b643-b5f1b530bdd9: 6e927b5b-b40c-4b9f-b643-b5f1b530bdd9 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:00.623670 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles failed. 2025.07.28 06:36:00.623874 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:00.624461 [ 42836 ] {7c959e01-454a-46a7-8c82-0fba8f77243e} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:00.624671 [ 42836 ] {7c959e01-454a-46a7-8c82-0fba8f77243e} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:00.624754 [ 42836 ] {7c959e01-454a-46a7-8c82-0fba8f77243e} Application: Connection to mysql failed 1 times 2025.07.28 06:36:00.638424 [ 2061 ] {} MYSQL-Session-f6207de5-0a68-4a2b-a6ca-492829c3259c: f6207de5-0a68-4a2b-a6ca-492829c3259c Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:00.638570 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles failed. 2025.07.28 06:36:00.638729 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:00.639182 [ 42836 ] {7c959e01-454a-46a7-8c82-0fba8f77243e} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:00.639389 [ 42836 ] {7c959e01-454a-46a7-8c82-0fba8f77243e} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:00.639513 [ 42836 ] {7c959e01-454a-46a7-8c82-0fba8f77243e} Application: Connection to mysql failed 2 times 2025.07.28 06:36:00.654284 [ 2061 ] {} MYSQL-Session-d0b197dd-6438-4901-8f9c-c4250ebf5601: d0b197dd-6438-4901-8f9c-c4250ebf5601 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:00.654507 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles failed. 2025.07.28 06:36:00.654751 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:00.655123 [ 42836 ] {7c959e01-454a-46a7-8c82-0fba8f77243e} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:00.655295 [ 42836 ] {7c959e01-454a-46a7-8c82-0fba8f77243e} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:00.655356 [ 42836 ] {7c959e01-454a-46a7-8c82-0fba8f77243e} Application: Connection to mysql failed 3 times 2025.07.28 06:36:00.656673 [ 42836 ] {7c959e01-454a-46a7-8c82-0fba8f77243e} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43564) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:00.657678 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:01.102001 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles failed. 2025.07.28 06:36:01.102234 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:01.102687 [ 42836 ] {dd51405c-903b-4327-baac-278ad393d803} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:01.103033 [ 42836 ] {dd51405c-903b-4327-baac-278ad393d803} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:01.103123 [ 42836 ] {dd51405c-903b-4327-baac-278ad393d803} Application: Connection to mysql failed 1 times 2025.07.28 06:36:01.118654 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles failed. 2025.07.28 06:36:01.118866 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:01.119198 [ 42836 ] {dd51405c-903b-4327-baac-278ad393d803} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:01.119365 [ 42836 ] {dd51405c-903b-4327-baac-278ad393d803} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:01.119426 [ 42836 ] {dd51405c-903b-4327-baac-278ad393d803} Application: Connection to mysql failed 2 times 2025.07.28 06:36:01.132593 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles failed. 2025.07.28 06:36:01.132759 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:01.133146 [ 42836 ] {dd51405c-903b-4327-baac-278ad393d803} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:01.133345 [ 42836 ] {dd51405c-903b-4327-baac-278ad393d803} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:01.133412 [ 42836 ] {dd51405c-903b-4327-baac-278ad393d803} Application: Connection to mysql failed 3 times 2025.07.28 06:36:01.134714 [ 42836 ] {dd51405c-903b-4327-baac-278ad393d803} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43572) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:01.135762 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:01.570079 [ 42861 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:36:01.571017 [ 45958 ] {} POSTGRESQL-Session-a1d83293-32ef-4684-b435-9c578c8bba9d: a1d83293-32ef-4684-b435-9c578c8bba9d Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:01.571313 [ 45958 ] {} PostgreSQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:01.571520 [ 42836 ] {818cbfa8-6e9f-4a69-9448-9edc276cfffc} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:36:01.575293 [ 45958 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:36:01.576282 [ 42861 ] {} POSTGRESQL-Session-b13f34e9-a6fe-4132-9eec-72e4d83dcc13: b13f34e9-a6fe-4132-9eec-72e4d83dcc13 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:01.576647 [ 42861 ] {} PostgreSQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:01.576945 [ 42836 ] {818cbfa8-6e9f-4a69-9448-9edc276cfffc} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:36:01.578659 [ 42836 ] {818cbfa8-6e9f-4a69-9448-9edc276cfffc} executeQuery: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43578) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM postgresql('localhost:9005', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:36:01.579778 [ 42836 ] {} TCPHandler: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:36:02.012554 [ 42861 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:36:02.014940 [ 45958 ] {} PostgreSQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:02.015165 [ 42836 ] {d4e2ac16-fae0-4c99-9103-519a87207103} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:36:02.018430 [ 45958 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:36:02.020199 [ 42861 ] {} PostgreSQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:02.020404 [ 42836 ] {d4e2ac16-fae0-4c99-9103-519a87207103} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:36:02.021585 [ 42836 ] {d4e2ac16-fae0-4c99-9103-519a87207103} executeQuery: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43582) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM postgresql('localhost:9005', 'system', 'one', 'session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:36:02.022536 [ 42836 ] {} TCPHandler: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:36:04.318580 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:04.318816 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:04.704802 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:04.705050 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:04.755247 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:04.764690 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:04.792518 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:04.802532 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:05.930374 [ 2061 ] {} MYSQL-Session-b45de22f-405d-430b-b4a5-fd18b7bcf5ce: b45de22f-405d-430b-b4a5-fd18b7bcf5ce Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:05.930626 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles failed. 2025.07.28 06:36:05.930821 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:05.932418 [ 42836 ] {57370cb4-dd24-4666-b947-2e1ddec3abca} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:05.933055 [ 42836 ] {57370cb4-dd24-4666-b947-2e1ddec3abca} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:05.933247 [ 42836 ] {57370cb4-dd24-4666-b947-2e1ddec3abca} Application: Connection to mysql failed 1 times 2025.07.28 06:36:05.955814 [ 2061 ] {} MYSQL-Session-43e1a4b2-bd61-4926-a26f-caa371e04d87: 43e1a4b2-bd61-4926-a26f-caa371e04d87 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:05.955995 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles failed. 2025.07.28 06:36:05.956161 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:05.957084 [ 42836 ] {57370cb4-dd24-4666-b947-2e1ddec3abca} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:05.957456 [ 42836 ] {57370cb4-dd24-4666-b947-2e1ddec3abca} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:05.957543 [ 42836 ] {57370cb4-dd24-4666-b947-2e1ddec3abca} Application: Connection to mysql failed 2 times 2025.07.28 06:36:05.976597 [ 2061 ] {} MYSQL-Session-c627ccb3-d44f-4c1d-b0cc-8d381744a5e4: c627ccb3-d44f-4c1d-b0cc-8d381744a5e4 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:05.976749 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles failed. 2025.07.28 06:36:05.976948 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:05.977885 [ 42836 ] {57370cb4-dd24-4666-b947-2e1ddec3abca} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:05.978173 [ 42836 ] {57370cb4-dd24-4666-b947-2e1ddec3abca} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:05.978269 [ 42836 ] {57370cb4-dd24-4666-b947-2e1ddec3abca} Application: Connection to mysql failed 3 times 2025.07.28 06:36:05.980910 [ 42836 ] {57370cb4-dd24-4666-b947-2e1ddec3abca} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43658) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:05.983002 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:06.444220 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles failed. 2025.07.28 06:36:06.444417 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:06.445270 [ 42836 ] {b77e16a9-8e34-4dfe-91b0-9e9be697ff95} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:06.445595 [ 42836 ] {b77e16a9-8e34-4dfe-91b0-9e9be697ff95} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:06.445694 [ 42836 ] {b77e16a9-8e34-4dfe-91b0-9e9be697ff95} Application: Connection to mysql failed 1 times 2025.07.28 06:36:06.465521 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles failed. 2025.07.28 06:36:06.465728 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:06.466597 [ 42836 ] {b77e16a9-8e34-4dfe-91b0-9e9be697ff95} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:06.466916 [ 42836 ] {b77e16a9-8e34-4dfe-91b0-9e9be697ff95} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:06.467024 [ 42836 ] {b77e16a9-8e34-4dfe-91b0-9e9be697ff95} Application: Connection to mysql failed 2 times 2025.07.28 06:36:06.484982 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles failed. 2025.07.28 06:36:06.485152 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:06.485982 [ 42836 ] {b77e16a9-8e34-4dfe-91b0-9e9be697ff95} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:06.486290 [ 42836 ] {b77e16a9-8e34-4dfe-91b0-9e9be697ff95} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:06.486518 [ 42836 ] {b77e16a9-8e34-4dfe-91b0-9e9be697ff95} Application: Connection to mysql failed 3 times 2025.07.28 06:36:06.488648 [ 42836 ] {b77e16a9-8e34-4dfe-91b0-9e9be697ff95} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43666) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:06.490404 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:06.935458 [ 42861 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:36:06.936663 [ 45958 ] {} POSTGRESQL-Session-c2d8843c-b380-49e5-abfa-9c4ce3add8c8: c2d8843c-b380-49e5-abfa-9c4ce3add8c8 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:06.936909 [ 45958 ] {} PostgreSQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:06.937480 [ 42836 ] {f77233f6-2d20-47af-8772-1cb3db347bba} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:36:06.943207 [ 45958 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:36:06.944250 [ 42861 ] {} POSTGRESQL-Session-f9435ae7-6155-4954-ad94-bb830677f09c: f9435ae7-6155-4954-ad94-bb830677f09c Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:06.944485 [ 42861 ] {} PostgreSQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:06.945218 [ 42836 ] {f77233f6-2d20-47af-8772-1cb3db347bba} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:36:06.948022 [ 42836 ] {f77233f6-2d20-47af-8772-1cb3db347bba} executeQuery: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43670) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM postgresql('localhost:9005', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:36:06.950528 [ 42836 ] {} TCPHandler: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:36:07.401051 [ 42861 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:36:07.403194 [ 45958 ] {} PostgreSQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:07.403550 [ 42836 ] {3336bee0-195c-4f58-8eb2-a2e9f1183d2b} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:36:07.408200 [ 45958 ] {} PostgreSQLHandler: DB::Exception: Cannot read all data. Bytes read: 0. Bytes expected: 4. 2025.07.28 06:36:07.409965 [ 42861 ] {} PostgreSQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:07.410282 [ 42836 ] {3336bee0-195c-4f58-8eb2-a2e9f1183d2b} PostgreSQLConnectionPool: Connection error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password 2025.07.28 06:36:07.412054 [ 42836 ] {3336bee0-195c-4f58-8eb2-a2e9f1183d2b} executeQuery: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42290) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM postgresql('localhost:9005', 'system', 'one', 'session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_plaintext_password_two_profiles_two_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:36:07.413649 [ 42836 ] {} TCPHandler: Code: 614. DB::Exception: Try 2. Connection to `localhost:9005` failed with error: connection to server at "localhost" (::1), port 9005 failed: could not open certificate file "/root/.postgresql/postgresql.crt": Permission denied connection to server at "localhost" (::1), port 9005 failed: ERROR: Invalid user or password . (POSTGRESQL_CONNECTION_FAILURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x0000000016835fcb 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac143bb 5. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:97: DB::StoragePostgreSQL::StoragePostgreSQL(DB::StorageID const&, std::shared_ptr, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String const&, String const&) @ 0x000000001ac13e9e 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, String const&, 0>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, String const&) @ 0x0000000013cfeea7 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionPostgreSQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfe406 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 30. __tsan_thread_start_func @ 0x0000000008756428 31. ? @ 0x00007fecd6763ac3 2025.07.28 06:36:10.176184 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:10.176408 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:10.584237 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:10.584612 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:10.633039 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:10.641132 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:10.667255 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:10.674383 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:11.072126 [ 2061 ] {} MYSQL-Session-42d58d67-b7bc-4c03-974a-8019e8885ae2: 42d58d67-b7bc-4c03-974a-8019e8885ae2 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles` in user directories 2025.07.28 06:36:11.072277 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles failed. 2025.07.28 06:36:11.072445 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles` in user directories 2025.07.28 06:36:11.072927 [ 42836 ] {e7ec6d5f-701f-499a-b6ee-3a1d5762f01e} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:11.073156 [ 42836 ] {e7ec6d5f-701f-499a-b6ee-3a1d5762f01e} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:11.073227 [ 42836 ] {e7ec6d5f-701f-499a-b6ee-3a1d5762f01e} Application: Connection to mysql failed 1 times 2025.07.28 06:36:11.085363 [ 2061 ] {} MYSQL-Session-ccb4c077-e1d9-4b4e-9e47-2fcfb6a270f0: ccb4c077-e1d9-4b4e-9e47-2fcfb6a270f0 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles` in user directories 2025.07.28 06:36:11.085514 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles failed. 2025.07.28 06:36:11.085680 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles` in user directories 2025.07.28 06:36:11.086121 [ 42836 ] {e7ec6d5f-701f-499a-b6ee-3a1d5762f01e} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:11.086314 [ 42836 ] {e7ec6d5f-701f-499a-b6ee-3a1d5762f01e} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:11.086459 [ 42836 ] {e7ec6d5f-701f-499a-b6ee-3a1d5762f01e} Application: Connection to mysql failed 2 times 2025.07.28 06:36:11.099045 [ 2061 ] {} MYSQL-Session-bdd953df-5c01-4ad1-8809-1c0439937736: bdd953df-5c01-4ad1-8809-1c0439937736 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles` in user directories 2025.07.28 06:36:11.099181 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles failed. 2025.07.28 06:36:11.099341 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles` in user directories 2025.07.28 06:36:11.099733 [ 42836 ] {e7ec6d5f-701f-499a-b6ee-3a1d5762f01e} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:11.100014 [ 42836 ] {e7ec6d5f-701f-499a-b6ee-3a1d5762f01e} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:11.100141 [ 42836 ] {e7ec6d5f-701f-499a-b6ee-3a1d5762f01e} Application: Connection to mysql failed 3 times 2025.07.28 06:36:11.102110 [ 42836 ] {e7ec6d5f-701f-499a-b6ee-3a1d5762f01e} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42352) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:11.103544 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:11.663258 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles failed. 2025.07.28 06:36:11.663475 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:11.664298 [ 42836 ] {a03dddbd-0994-443c-ac35-d6a3b2b56066} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:11.664514 [ 42836 ] {a03dddbd-0994-443c-ac35-d6a3b2b56066} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:11.664577 [ 42836 ] {a03dddbd-0994-443c-ac35-d6a3b2b56066} Application: Connection to mysql failed 1 times 2025.07.28 06:36:11.676488 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles failed. 2025.07.28 06:36:11.676646 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:11.677059 [ 42836 ] {a03dddbd-0994-443c-ac35-d6a3b2b56066} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:11.677261 [ 42836 ] {a03dddbd-0994-443c-ac35-d6a3b2b56066} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:11.677335 [ 42836 ] {a03dddbd-0994-443c-ac35-d6a3b2b56066} Application: Connection to mysql failed 2 times 2025.07.28 06:36:11.687992 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles failed. 2025.07.28 06:36:11.688148 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:11.688524 [ 42836 ] {a03dddbd-0994-443c-ac35-d6a3b2b56066} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:11.688724 [ 42836 ] {a03dddbd-0994-443c-ac35-d6a3b2b56066} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:11.688814 [ 42836 ] {a03dddbd-0994-443c-ac35-d6a3b2b56066} Application: Connection to mysql failed 3 times 2025.07.28 06:36:11.690002 [ 42836 ] {a03dddbd-0994-443c-ac35-d6a3b2b56066} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42360) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:11.690856 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:14.427653 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:14.427911 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:14.806948 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:14.807225 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:14.860116 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:14.869153 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:14.899593 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:14.907538 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:15.397452 [ 2061 ] {} MYSQL-Session-fc34ff7b-96fd-4593-b324-809fafcbaf49: fc34ff7b-96fd-4593-b324-809fafcbaf49 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:15.397590 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles failed. 2025.07.28 06:36:15.397768 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:15.398292 [ 42836 ] {344f0f79-2286-4581-8296-a08f12500f58} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:15.398548 [ 42836 ] {344f0f79-2286-4581-8296-a08f12500f58} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:15.398622 [ 42836 ] {344f0f79-2286-4581-8296-a08f12500f58} Application: Connection to mysql failed 1 times 2025.07.28 06:36:15.411746 [ 2061 ] {} MYSQL-Session-d08f47bd-735d-420d-a0a5-15683ea59007: d08f47bd-735d-420d-a0a5-15683ea59007 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:15.411952 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles failed. 2025.07.28 06:36:15.412139 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:15.412557 [ 42836 ] {344f0f79-2286-4581-8296-a08f12500f58} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:15.412763 [ 42836 ] {344f0f79-2286-4581-8296-a08f12500f58} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:15.412853 [ 42836 ] {344f0f79-2286-4581-8296-a08f12500f58} Application: Connection to mysql failed 2 times 2025.07.28 06:36:15.428049 [ 2061 ] {} MYSQL-Session-e6ea196a-c1b7-4297-b2de-e178a7d08c99: e6ea196a-c1b7-4297-b2de-e178a7d08c99 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:15.428193 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles failed. 2025.07.28 06:36:15.428350 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:15.428753 [ 42836 ] {344f0f79-2286-4581-8296-a08f12500f58} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:15.428978 [ 42836 ] {344f0f79-2286-4581-8296-a08f12500f58} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:15.429030 [ 42836 ] {344f0f79-2286-4581-8296-a08f12500f58} Application: Connection to mysql failed 3 times 2025.07.28 06:36:15.430102 [ 42836 ] {344f0f79-2286-4581-8296-a08f12500f58} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42432) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:15.430945 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:15.869534 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles failed. 2025.07.28 06:36:15.869725 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:15.870693 [ 42836 ] {143fc22e-cbbb-48a8-a099-6c52e1718c23} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:15.871103 [ 42836 ] {143fc22e-cbbb-48a8-a099-6c52e1718c23} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:15.871272 [ 42836 ] {143fc22e-cbbb-48a8-a099-6c52e1718c23} Application: Connection to mysql failed 1 times 2025.07.28 06:36:15.885900 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles failed. 2025.07.28 06:36:15.886056 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:15.886473 [ 42836 ] {143fc22e-cbbb-48a8-a099-6c52e1718c23} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:15.886662 [ 42836 ] {143fc22e-cbbb-48a8-a099-6c52e1718c23} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:15.886750 [ 42836 ] {143fc22e-cbbb-48a8-a099-6c52e1718c23} Application: Connection to mysql failed 2 times 2025.07.28 06:36:15.902609 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles failed. 2025.07.28 06:36:15.902818 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:15.903186 [ 42836 ] {143fc22e-cbbb-48a8-a099-6c52e1718c23} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:15.903410 [ 42836 ] {143fc22e-cbbb-48a8-a099-6c52e1718c23} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:15.903479 [ 42836 ] {143fc22e-cbbb-48a8-a099-6c52e1718c23} Application: Connection to mysql failed 3 times 2025.07.28 06:36:15.904774 [ 42836 ] {143fc22e-cbbb-48a8-a099-6c52e1718c23} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42438) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:15.905917 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:18.659529 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:18.659910 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:19.036740 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:19.037203 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:19.091822 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:19.100081 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:19.125618 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:19.132934 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:19.560747 [ 2061 ] {} MYSQL-Session-cc2a794f-b4de-44bd-ad63-023919b58a25: cc2a794f-b4de-44bd-ad63-023919b58a25 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:19.561049 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles failed. 2025.07.28 06:36:19.561343 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:19.562074 [ 42836 ] {a901ecb1-2869-4e7c-8bcc-166eb4fa3bad} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:19.562459 [ 42836 ] {a901ecb1-2869-4e7c-8bcc-166eb4fa3bad} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:19.562633 [ 42836 ] {a901ecb1-2869-4e7c-8bcc-166eb4fa3bad} Application: Connection to mysql failed 1 times 2025.07.28 06:36:19.588062 [ 2061 ] {} MYSQL-Session-f0c79aab-3b6f-4466-9435-0137350029ba: f0c79aab-3b6f-4466-9435-0137350029ba Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:19.588466 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles failed. 2025.07.28 06:36:19.588738 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:19.589504 [ 42836 ] {a901ecb1-2869-4e7c-8bcc-166eb4fa3bad} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:19.590068 [ 42836 ] {a901ecb1-2869-4e7c-8bcc-166eb4fa3bad} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:19.590336 [ 42836 ] {a901ecb1-2869-4e7c-8bcc-166eb4fa3bad} Application: Connection to mysql failed 2 times 2025.07.28 06:36:19.618027 [ 2061 ] {} MYSQL-Session-81ed27b4-7855-4b55-96ed-34e434ba3640: 81ed27b4-7855-4b55-96ed-34e434ba3640 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:19.618281 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles failed. 2025.07.28 06:36:19.618614 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:19.619264 [ 42836 ] {a901ecb1-2869-4e7c-8bcc-166eb4fa3bad} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:19.619593 [ 42836 ] {a901ecb1-2869-4e7c-8bcc-166eb4fa3bad} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:19.619724 [ 42836 ] {a901ecb1-2869-4e7c-8bcc-166eb4fa3bad} Application: Connection to mysql failed 3 times 2025.07.28 06:36:19.621828 [ 42836 ] {a901ecb1-2869-4e7c-8bcc-166eb4fa3bad} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60038) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:19.623591 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:20.058279 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles failed. 2025.07.28 06:36:20.058469 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:20.058957 [ 42836 ] {7f629c20-c938-4c56-a854-2ce5e1ec6855} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:20.059166 [ 42836 ] {7f629c20-c938-4c56-a854-2ce5e1ec6855} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:20.059234 [ 42836 ] {7f629c20-c938-4c56-a854-2ce5e1ec6855} Application: Connection to mysql failed 1 times 2025.07.28 06:36:20.072328 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles failed. 2025.07.28 06:36:20.072505 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:20.072947 [ 42836 ] {7f629c20-c938-4c56-a854-2ce5e1ec6855} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:20.073128 [ 42836 ] {7f629c20-c938-4c56-a854-2ce5e1ec6855} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:20.073221 [ 42836 ] {7f629c20-c938-4c56-a854-2ce5e1ec6855} Application: Connection to mysql failed 2 times 2025.07.28 06:36:20.087282 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles failed. 2025.07.28 06:36:20.087495 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:20.088046 [ 42836 ] {7f629c20-c938-4c56-a854-2ce5e1ec6855} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:20.088290 [ 42836 ] {7f629c20-c938-4c56-a854-2ce5e1ec6855} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:20.088382 [ 42836 ] {7f629c20-c938-4c56-a854-2ce5e1ec6855} Application: Connection to mysql failed 3 times 2025.07.28 06:36:20.089713 [ 42836 ] {7f629c20-c938-4c56-a854-2ce5e1ec6855} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60046) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:20.090814 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_sha256_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:22.899553 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:22.899974 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:23.280009 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:23.280237 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:23.329364 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:23.336381 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:23.365513 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:23.376938 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:24.404428 [ 2061 ] {} MYSQL-Session-a30e5db4-e4db-422e-93cc-d46da223d566: a30e5db4-e4db-422e-93cc-d46da223d566 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles` in user directories 2025.07.28 06:36:24.404599 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles failed. 2025.07.28 06:36:24.404773 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles` in user directories 2025.07.28 06:36:24.405255 [ 42836 ] {be410719-01d6-4ddc-9366-c5aea5612fbc} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:24.405479 [ 42836 ] {be410719-01d6-4ddc-9366-c5aea5612fbc} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:24.405551 [ 42836 ] {be410719-01d6-4ddc-9366-c5aea5612fbc} Application: Connection to mysql failed 1 times 2025.07.28 06:36:24.418760 [ 2061 ] {} MYSQL-Session-853407f1-b1cf-4ed5-85b3-e7a7f1b9a456: 853407f1-b1cf-4ed5-85b3-e7a7f1b9a456 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles` in user directories 2025.07.28 06:36:24.418922 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles failed. 2025.07.28 06:36:24.419093 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles` in user directories 2025.07.28 06:36:24.419473 [ 42836 ] {be410719-01d6-4ddc-9366-c5aea5612fbc} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:24.419697 [ 42836 ] {be410719-01d6-4ddc-9366-c5aea5612fbc} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:24.419763 [ 42836 ] {be410719-01d6-4ddc-9366-c5aea5612fbc} Application: Connection to mysql failed 2 times 2025.07.28 06:36:24.433319 [ 2061 ] {} MYSQL-Session-5f450343-b89f-40d1-8348-452e53775dd8: 5f450343-b89f-40d1-8348-452e53775dd8 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles` in user directories 2025.07.28 06:36:24.433465 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles failed. 2025.07.28 06:36:24.433632 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles` in user directories 2025.07.28 06:36:24.434086 [ 42836 ] {be410719-01d6-4ddc-9366-c5aea5612fbc} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:24.434408 [ 42836 ] {be410719-01d6-4ddc-9366-c5aea5612fbc} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:24.434484 [ 42836 ] {be410719-01d6-4ddc-9366-c5aea5612fbc} Application: Connection to mysql failed 3 times 2025.07.28 06:36:24.436157 [ 42836 ] {be410719-01d6-4ddc-9366-c5aea5612fbc} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60126) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:24.437323 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:24.883092 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles failed. 2025.07.28 06:36:24.883264 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:24.883799 [ 42836 ] {2170b574-60c7-4426-aaea-1c4be020c203} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:24.884034 [ 42836 ] {2170b574-60c7-4426-aaea-1c4be020c203} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:24.884108 [ 42836 ] {2170b574-60c7-4426-aaea-1c4be020c203} Application: Connection to mysql failed 1 times 2025.07.28 06:36:24.898433 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles failed. 2025.07.28 06:36:24.898593 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:24.899050 [ 42836 ] {2170b574-60c7-4426-aaea-1c4be020c203} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:24.899340 [ 42836 ] {2170b574-60c7-4426-aaea-1c4be020c203} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:24.899413 [ 42836 ] {2170b574-60c7-4426-aaea-1c4be020c203} Application: Connection to mysql failed 2 times 2025.07.28 06:36:24.912348 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles failed. 2025.07.28 06:36:24.912499 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:24.912921 [ 42836 ] {2170b574-60c7-4426-aaea-1c4be020c203} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:24.913148 [ 42836 ] {2170b574-60c7-4426-aaea-1c4be020c203} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:24.913230 [ 42836 ] {2170b574-60c7-4426-aaea-1c4be020c203} Application: Connection to mysql failed 3 times 2025.07.28 06:36:24.914675 [ 42836 ] {2170b574-60c7-4426-aaea-1c4be020c203} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:60132) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:24.915966 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_no_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:27.639769 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:27.640106 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:28.016209 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:28.016599 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:28.077025 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:28.087022 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:28.119078 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:28.129971 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:29.176313 [ 2061 ] {} MYSQL-Session-8706546e-9128-4d55-9d12-a07a05bca6d0: 8706546e-9128-4d55-9d12-a07a05bca6d0 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:29.176458 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles failed. 2025.07.28 06:36:29.176623 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:29.177308 [ 42836 ] {564db2b2-39af-4c75-ba5d-f11206579a83} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:29.177528 [ 42836 ] {564db2b2-39af-4c75-ba5d-f11206579a83} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:29.177594 [ 42836 ] {564db2b2-39af-4c75-ba5d-f11206579a83} Application: Connection to mysql failed 1 times 2025.07.28 06:36:29.189949 [ 2061 ] {} MYSQL-Session-94831526-e012-4a3a-86a4-3d98ce405aea: 94831526-e012-4a3a-86a4-3d98ce405aea Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:29.190103 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles failed. 2025.07.28 06:36:29.190272 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:29.190636 [ 42836 ] {564db2b2-39af-4c75-ba5d-f11206579a83} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:29.190843 [ 42836 ] {564db2b2-39af-4c75-ba5d-f11206579a83} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:29.190921 [ 42836 ] {564db2b2-39af-4c75-ba5d-f11206579a83} Application: Connection to mysql failed 2 times 2025.07.28 06:36:29.203016 [ 2061 ] {} MYSQL-Session-0abd16f1-bd57-464b-8c32-1f052a12be3d: 0abd16f1-bd57-464b-8c32-1f052a12be3d Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:29.203215 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles failed. 2025.07.28 06:36:29.203387 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles` in user directories 2025.07.28 06:36:29.203714 [ 42836 ] {564db2b2-39af-4c75-ba5d-f11206579a83} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:29.203917 [ 42836 ] {564db2b2-39af-4c75-ba5d-f11206579a83} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:29.204004 [ 42836 ] {564db2b2-39af-4c75-ba5d-f11206579a83} Application: Connection to mysql failed 3 times 2025.07.28 06:36:29.205298 [ 42836 ] {564db2b2-39af-4c75-ba5d-f11206579a83} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55218) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:29.206408 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:29.645170 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles failed. 2025.07.28 06:36:29.645336 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:29.645863 [ 42836 ] {6306e03a-f03d-48ad-9562-0b335a9f44ee} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:29.646093 [ 42836 ] {6306e03a-f03d-48ad-9562-0b335a9f44ee} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:29.646162 [ 42836 ] {6306e03a-f03d-48ad-9562-0b335a9f44ee} Application: Connection to mysql failed 1 times 2025.07.28 06:36:29.660938 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles failed. 2025.07.28 06:36:29.661075 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:29.661690 [ 42836 ] {6306e03a-f03d-48ad-9562-0b335a9f44ee} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:29.661865 [ 42836 ] {6306e03a-f03d-48ad-9562-0b335a9f44ee} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:29.661972 [ 42836 ] {6306e03a-f03d-48ad-9562-0b335a9f44ee} Application: Connection to mysql failed 2 times 2025.07.28 06:36:29.673718 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles failed. 2025.07.28 06:36:29.673848 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:29.674261 [ 42836 ] {6306e03a-f03d-48ad-9562-0b335a9f44ee} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:29.674473 [ 42836 ] {6306e03a-f03d-48ad-9562-0b335a9f44ee} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:29.674538 [ 42836 ] {6306e03a-f03d-48ad-9562-0b335a9f44ee} Application: Connection to mysql failed 3 times 2025.07.28 06:36:29.675793 [ 42836 ] {6306e03a-f03d-48ad-9562-0b335a9f44ee} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55234) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:29.676923 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_no_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:32.545293 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:32.545559 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:32.926939 [ 42836 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:32.927147 [ 42836 ] {} ServerErrorHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afa60a 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000001bbe4c1d 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000001bbd909e 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:32.984753 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:32.994684 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:33.025972 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:33.036981 [ 42863 ] {} DynamicQueryHandler: Code: 516. DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000016c80e35 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000018afadb4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001bc203f9 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001bb1b0e4 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb1b664 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:34.140491 [ 2061 ] {} MYSQL-Session-967e34d8-6c0e-4f39-b449-2248c38c58f8: 967e34d8-6c0e-4f39-b449-2248c38c58f8 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:34.140725 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles failed. 2025.07.28 06:36:34.140928 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:34.141531 [ 42836 ] {7d92ebb9-85d9-4741-98d6-31d09de77b97} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:34.141780 [ 42836 ] {7d92ebb9-85d9-4741-98d6-31d09de77b97} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:34.141848 [ 42836 ] {7d92ebb9-85d9-4741-98d6-31d09de77b97} Application: Connection to mysql failed 1 times 2025.07.28 06:36:34.154385 [ 2061 ] {} MYSQL-Session-8429035a-34db-483b-8f35-f01597f0dba7: 8429035a-34db-483b-8f35-f01597f0dba7 Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:34.154538 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles failed. 2025.07.28 06:36:34.154718 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:34.155091 [ 42836 ] {7d92ebb9-85d9-4741-98d6-31d09de77b97} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:34.155267 [ 42836 ] {7d92ebb9-85d9-4741-98d6-31d09de77b97} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:34.155359 [ 42836 ] {7d92ebb9-85d9-4741-98d6-31d09de77b97} Application: Connection to mysql failed 2 times 2025.07.28 06:36:34.167174 [ 2061 ] {} MYSQL-Session-9448563b-6b9e-4e02-a4a4-8bf4b7df475a: 9448563b-6b9e-4e02-a4a4-8bf4b7df475a Authentication failed with error: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:34.167347 [ 2061 ] {} MySQLHandler: Authentication for user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles failed. 2025.07.28 06:36:34.167502 [ 2061 ] {} MySQLHandler: DB::Exception: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles` in user directories 2025.07.28 06:36:34.167846 [ 42836 ] {7d92ebb9-85d9-4741-98d6-31d09de77b97} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:34.168035 [ 42836 ] {7d92ebb9-85d9-4741-98d6-31d09de77b97} Application: Connection to system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles` in user directories ((nullptr):9004) 2025.07.28 06:36:34.168111 [ 42836 ] {7d92ebb9-85d9-4741-98d6-31d09de77b97} Application: Connection to mysql failed 3 times 2025.07.28 06:36:34.169779 [ 42836 ] {7d92ebb9-85d9-4741-98d6-31d09de77b97} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55320) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:34.170944 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles, ERROR 192 : mysqlxx::ConnectionFailed: There is no user `invalid_session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles` in user directories ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:34.626824 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles failed. 2025.07.28 06:36:34.627008 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:34.627798 [ 42836 ] {bc5c5733-4c95-40c0-84c6-e8505db7ad6b} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:34.628123 [ 42836 ] {bc5c5733-4c95-40c0-84c6-e8505db7ad6b} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:34.628227 [ 42836 ] {bc5c5733-4c95-40c0-84c6-e8505db7ad6b} Application: Connection to mysql failed 1 times 2025.07.28 06:36:34.645306 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles failed. 2025.07.28 06:36:34.645480 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:34.646325 [ 42836 ] {bc5c5733-4c95-40c0-84c6-e8505db7ad6b} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:34.646647 [ 42836 ] {bc5c5733-4c95-40c0-84c6-e8505db7ad6b} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:34.646760 [ 42836 ] {bc5c5733-4c95-40c0-84c6-e8505db7ad6b} Application: Connection to mysql failed 2 times 2025.07.28 06:36:34.662643 [ 2061 ] {} MySQLHandler: Authentication for user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles failed. 2025.07.28 06:36:34.662819 [ 2061 ] {} MySQLHandler: DB::Exception: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. 2025.07.28 06:36:34.663640 [ 42836 ] {bc5c5733-4c95-40c0-84c6-e8505db7ad6b} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles): mysqlxx::ConnectionFailed 2025.07.28 06:36:34.663926 [ 42836 ] {bc5c5733-4c95-40c0-84c6-e8505db7ad6b} Application: Connection to system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles failed: mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.07.28 06:36:34.664044 [ 42836 ] {bc5c5733-4c95-40c0-84c6-e8505db7ad6b} Application: Connection to mysql failed 3 times 2025.07.28 06:36:34.665641 [ 42836 ] {bc5c5733-4c95-40c0-84c6-e8505db7ad6b} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:55330) (comment: 01747_system_session_log_long.sh) (query 1, line 1) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', 'session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles', '[HIDDEN]') LIMIT 1 FORMAT `Null`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:34.666812 [ 42836 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles, ERROR 516 : mysqlxx::ConnectionFailed: session_log_test_user_1da8dddc0faf584a568ebd448d079fbf_double_sha1_password_two_profiles_two_roles: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008802220 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x0000000020da9a91 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001785234e 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000001ac0b3e9 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x000000001ac0abff 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000013cfcf2e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000013cfbdb9 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016482f8d 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181a5e61 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000017a8d34f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000017abc51b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ed97 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 2025.07.28 06:36:41.194260 [ 50382 ] {a2eaa586-c026-48b5-9810-0f0d86092617} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37272) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.195430 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.256618 [ 50383 ] {08843357-d26f-416b-90a9-b7bab6c3f45a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37328) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.257608 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.311878 [ 45958 ] {1f25b689-4b20-4762-bed5-ffa37ebca133} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37232) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.311975 [ 50385 ] {ceaa5582-dc65-4028-bccb-4910c21fef25} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37298) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.311978 [ 50381 ] {c6780c64-c332-4ea3-a3aa-a229d3d8e5e9} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37264) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.313048 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.313114 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.313428 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.313543 [ 50380 ] {0df95976-dcad-44dd-a43a-0dbeeb4b618f} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37254) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.313599 [ 42863 ] {680556f1-b5b4-426e-86c4-1ebf0723c8da} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37240) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.314284 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.314681 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.663006 [ 42863 ] {c0c8cb38-28ef-4b44-b298-770ad29428ef} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37346) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.663797 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.777184 [ 50382 ] {bb0e08af-dd6e-4736-a7a8-2a5a02f1211a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37378) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.778010 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.866079 [ 50384 ] {df57bea8-c51a-47cd-9872-00984c005aeb} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37392) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.866154 [ 50383 ] {9b37cde6-3865-42f0-b7a9-a85caa90b0da} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37432) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.867117 [ 50384 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.867415 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.875210 [ 50385 ] {297442f6-361b-4b45-80a6-113bbf26d348} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37420) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:41.876215 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:42.171060 [ 50381 ] {780c3a0e-5d7b-4bc0-ab23-99378c9a99ab} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37468) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:42.172118 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:42.409389 [ 50387 ] {b3255714-435e-4af1-af6c-37982e50e3cf} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37584) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:42.410301 [ 50387 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:42.700711 [ 50380 ] {cbf184da-131a-457f-912f-97fc2cd46c73} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37602) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:42.701881 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:42.849051 [ 50382 ] {ac35cf65-8cef-4e2c-b886-6f343cda5b37} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37616) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:42.849951 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:43.591175 [ 50381 ] {98668e60-4940-411d-8cf4-a66fe5429ea6} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37788) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:43.591971 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:43.643173 [ 50382 ] {dabd2143-14cf-4c34-9546-6cb407ca04d8} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37792) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:43.644468 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:43.695217 [ 50380 ] {52cbde07-51d9-4d54-b628-6bece26447ab} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37806) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:43.696660 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:43.965575 [ 50381 ] {3cb99889-c107-4c2e-a51e-787f4ba3f45e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37876) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:43.966874 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.108621 [ 50381 ] {8b44e0b7-89d0-492e-b6f9-4b8d8ed088fe} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37886) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.110484 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.156896 [ 50382 ] {628a619e-4832-4831-9351-507a7c44b83d} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37890) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.157887 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.192877 [ 50381 ] {e9d76cdc-8054-4008-a8de-d43dcea2f9d7} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37894) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.194325 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.276577 [ 50380 ] {9ac081d6-4abb-4ed2-8a2f-d6458fbbeb34} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37914) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.277484 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.295064 [ 50381 ] {da6585a6-e5b6-4f47-930f-233d5b5d5767} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37918) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.295890 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.334403 [ 50380 ] {e9d2aada-d39e-4324-9955-08a6f593c601} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37928) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.335393 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.569014 [ 50382 ] {41c7701f-030f-4ff2-b9ec-1137624d0287} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37964) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.569915 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.630000 [ 50380 ] {268eee4c-e1cc-4fc9-88d1-cb3f1b7f96bf} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37972) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.630945 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.659158 [ 50381 ] {d84a8dde-77a0-4814-8b8e-12b8ea491a74} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:37980) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.661051 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.714748 [ 50380 ] {8ef36353-e2c0-4099-b648-055efe49e10a} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38000) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.715730 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.742002 [ 50381 ] {9242fbed-e7ff-40e5-b309-3250c98f782b} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38016) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.742872 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.776812 [ 50380 ] {9336fa5d-aee9-4132-af81-fe8c0c916093} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38036) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.777754 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.783018 [ 50382 ] {d5035bf7-ebd3-48f9-8ef1-83e8492166b4} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38020) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:44.783798 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.005198 [ 50381 ] {809fea16-1cc2-428e-b985-9afcf61c82fd} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38070) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.006150 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.060172 [ 50380 ] {92297a45-7fc5-4862-bdbb-64ef7a391282} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38084) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.061126 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.105064 [ 50382 ] {a95cc211-d0e9-4e5e-8695-4acc1e0d4474} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38110) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.105381 [ 50381 ] {e1524c15-1eba-467d-a5de-81af23ed78a2} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38094) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.106190 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.106338 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.174880 [ 50385 ] {f78c54c4-d165-4803-849a-8757b9cb4f65} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38138) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.175863 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.195729 [ 50380 ] {82a0d185-04f6-43c2-a9ae-4e9c384a2805} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38148) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.196447 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.229766 [ 50381 ] {77f48ad5-15b9-44ff-a22b-a7acd0312549} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38156) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.230620 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.262809 [ 50382 ] {f31212a7-8f80-474f-8456-100c8bdb52d5} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38164) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.263862 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.480238 [ 50381 ] {d6acaaa7-213c-47c0-822e-092a760bba88} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38202) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.481263 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.520311 [ 50382 ] {1ac3cffb-6c25-494b-8c34-2000fb7a204b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38204) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.521689 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.549805 [ 50380 ] {75c9ff76-f30a-4c01-adf5-f5a887859e1c} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38218) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.550791 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.590901 [ 50381 ] {bde9d06a-fbf3-43fb-af8d-5116f205da01} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38232) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.591907 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.643516 [ 50380 ] {99a9f9b3-46ef-4a1e-ab3d-d0aff8bcc99b} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38252) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.644416 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.656898 [ 50381 ] {4d966ce3-5f62-454f-848d-103dfad1e6de} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38254) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.657814 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.716344 [ 50380 ] {02492cd9-5897-42bb-82bb-e8e1313c0f7e} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38266) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.717329 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.726578 [ 50381 ] {d411271d-8a39-4aec-be42-9151efbeb517} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38282) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:45.727513 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.050212 [ 50382 ] {2316ca28-5735-472f-8a33-d762b3852c2f} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38304) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.052327 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.096476 [ 50386 ] {a6491854-5a3e-4a09-8df7-d9601300fc92} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38306) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.097290 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.106207 [ 50387 ] {0c76b5bf-5116-47bd-800b-df60eaf1b85b} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38324) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.106995 [ 50387 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.128552 [ 50385 ] {547f9e2c-f71e-4a26-ac0e-4f8140db64d3} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38308) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.129719 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.165353 [ 50387 ] {c9a95183-dc72-481d-8edc-88da9cff62e0} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38352) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.166336 [ 50387 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.225821 [ 50382 ] {d1f1691b-c74c-47aa-9136-a80b76239c95} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38360) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.226948 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.390474 [ 50385 ] {c044cfbb-19cd-43a3-8b13-f8693abdd1d5} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38376) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.391483 [ 50385 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.567788 [ 50385 ] {0106e316-abd2-419c-800f-e1f3abc58879} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38396) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.568552 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.575906 [ 50381 ] {ce99bf23-29b5-4f93-8512-9438fb35f34a} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38382) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.576887 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.593732 [ 50386 ] {dfb1d525-9db1-4d5f-aa00-848bfb49c4c3} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38406) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.594603 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.607542 [ 50387 ] {3af1d6b9-013a-4f03-bcb0-c924b2161106} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38408) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.608652 [ 50387 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.745367 [ 50385 ] {ce3907c3-3047-46bf-a7ca-b8fa8d77b521} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38454) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.746327 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.883956 [ 50381 ] {f71f1de1-2994-4866-99e1-d8b9c01d2257} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:38484) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:46.884785 [ 50381 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.036191 [ 50382 ] {c7594d02-772c-4fb0-ac28-9902048ec733} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47876) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.037252 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.066835 [ 50385 ] {82da734c-71d2-4a72-b578-882aca34f186} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47892) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.067654 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.119210 [ 50381 ] {2320338e-6b19-4165-ac49-975d1749dc9c} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47894) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.120233 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.123576 [ 50382 ] {30a39df7-ac43-46bc-ae1b-e980ae291a69} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47910) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.124436 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.242025 [ 50382 ] {d417e48c-2474-4262-b498-879922204ace} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47934) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.242783 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.345053 [ 50382 ] {3e6b0d0a-ca68-45a4-8f9c-793a7945c5bf} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47976) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.345815 [ 50382 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.496487 [ 50381 ] {67d6895a-b729-4f3e-ba30-63282810f5f9} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:47994) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.497611 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.586635 [ 50381 ] {e8b520c0-7e33-4476-916a-f3964e139437} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48000) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.587510 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.638379 [ 50386 ] {a7c21532-dea4-4542-be2b-c4b8ddbe7cac} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48014) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.639232 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.690919 [ 50385 ] {7c749f19-b1f0-41cd-8089-68a861f7bc12} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48024) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.691712 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.816310 [ 50381 ] {b61a43d7-8029-4f59-8422-9cfb655e1728} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48048) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.817076 [ 50381 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.950115 [ 50385 ] {1ac7144d-0b4e-4647-bbbc-3f4ef8da24de} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48082) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:47.951045 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.077946 [ 50381 ] {a492a4f9-2f9e-439c-afa9-4be6cc1bbf37} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48090) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.078974 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.131182 [ 50386 ] {3d590f91-683e-4581-822f-45e4f2ee4622} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48118) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.131941 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.158198 [ 50381 ] {f3aefb7e-9827-41bc-bcb4-624e49dfb042} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48126) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.159259 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.266067 [ 50381 ] {6c7955b1-5784-479a-8301-981fcd233f10} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48170) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.266984 [ 50381 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.529063 [ 50385 ] {082391df-4582-4136-a586-610e4cb8f112} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48202) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.529947 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.606406 [ 50385 ] {ef6d24a0-000c-49ee-a60a-b7a7a27d23ff} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48234) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.607260 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.619580 [ 50386 ] {0d4db8c0-40fb-481a-a331-5ca99fd46e0e} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48240) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.620389 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.741979 [ 50386 ] {c849f032-702c-45fc-a35a-117d241e1035} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48286) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.742860 [ 50386 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.989639 [ 50388 ] {fabb11de-645a-43ab-aed4-b053d63a60de} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48316) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:48.990799 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.098029 [ 50388 ] {532d0206-efb9-4ed6-b7fe-367344cd1aa1} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48362) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.099151 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.117711 [ 50385 ] {269f598e-a5c1-49b8-a47d-e3e25fd23b08} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48370) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.118380 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.297178 [ 50385 ] {0739db69-5e42-4390-8bcc-89a9620a6cfd} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48394) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.298060 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.482823 [ 50387 ] {f8bec381-16d9-4aea-8910-abe811dc1339} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48422) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.483643 [ 50387 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.507057 [ 50385 ] {bde861a2-7a3d-4351-88ad-d8954e55bcd4} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48436) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.507744 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.515103 [ 45958 ] {1b7ac19a-de22-45a0-bd9e-13819b625a9a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48446) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.515848 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.575965 [ 50385 ] {b81b18e5-7fe3-40aa-b94b-c359f6288a02} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48454) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.576801 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.615899 [ 50387 ] {922bc2d6-1abd-47d4-8312-9c5fc9eab29c} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48456) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.617258 [ 50387 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.753301 [ 50385 ] {25181e15-d7eb-41ff-bd70-32d43d8f3f57} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48478) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.754181 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.946759 [ 50387 ] {f2c4a62e-b88c-4476-bbd9-b6121a8a432d} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48496) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.947598 [ 50387 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.950675 [ 42863 ] {58a842e4-ee7e-460f-8ac9-9d8c5bba4baa} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48518) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.951608 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.955454 [ 45958 ] {c51e2131-5938-435f-bac1-12a03266e778} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48514) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:49.956296 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.022489 [ 50385 ] {1090df9f-e6a5-4129-bc28-9b1aa2ab6ae6} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48538) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.023514 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.070780 [ 50388 ] {e52aafed-6a52-448c-90ce-247da7c6ed49} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48552) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.071742 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.196849 [ 50387 ] {9fdb4e7c-95a3-41ce-ad52-9596fc1b78a2} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48576) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.197553 [ 50387 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.445286 [ 50388 ] {4825b7b3-1bff-4df5-a8f3-9d37249d9b70} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48618) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.448012 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.489845 [ 50383 ] {d20fe6d1-5c3e-4061-91ee-bd2ca9204236} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48640) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.490911 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.523088 [ 50388 ] {248d43d8-c2ae-4ee2-88f8-45855471eb5d} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48662) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.523831 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.554525 [ 50385 ] {cbdf57ca-455a-484e-9d17-3baf344575b5} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48664) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.555720 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.692246 [ 50387 ] {e65068bd-dc84-410f-8e2b-4f69eba3b799} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48690) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.693186 [ 50387 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:50.814049 [ 50388 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:48692, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:50.814315 [ 50388 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:48692, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:36:51.198784 [ 50387 ] {d4f9a7b3-a020-4afb-892a-2fd2438caa6f} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48708) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.199485 [ 50387 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.213508 [ 50383 ] {3d652001-a697-4837-9e47-3ea7f2ceea08} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48748) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.213843 [ 50388 ] {61ad933a-8c43-4cae-827b-aeadc2f0b240} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48720) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.214467 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.214877 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.223090 [ 50380 ] {ccf73572-3d92-4504-aa2b-d03cbdcfb581} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48776) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.223889 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.250585 [ 50386 ] {b615359d-c648-4e23-b479-52d30019daa0} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48808) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.251898 [ 50386 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.259283 [ 50382 ] {1a86b544-e967-4774-bf29-f23f3dcb4908} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48796) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.260375 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.648391 [ 50380 ] {c336c3df-2690-4664-8bac-80b08906250a} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48830) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.650238 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.675795 [ 50387 ] {1e5e8535-d063-4a26-b2f0-6e1907f9e6a8} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48872) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.677718 [ 50387 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.758711 [ 50381 ] {63181e5d-a40c-4f01-962a-032296ff08e4} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48900) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.759622 [ 50381 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.790074 [ 50380 ] {94985b51-5176-4697-96e8-16d362658397} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48910) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:51.791494 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.094604 [ 50380 ] {fc9b0149-0ec5-4df7-918b-47b3a1dd4a84} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48928) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.096067 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.143664 [ 50385 ] {99930acd-b0f5-434a-9b02-45c16bfc8230} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48968) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.144547 [ 50385 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.208926 [ 50381 ] {b054fb1e-4a90-4c50-9c6e-7fce6dc26f41} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48980) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.209710 [ 50381 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.224462 [ 50382 ] {40c92e85-5b2e-4d46-b029-97771213dc4d} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48996) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.225426 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.252488 [ 50380 ] {2afe92ba-411b-4f11-a56d-39e8225f7dda} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49002) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.253471 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.295980 [ 50381 ] {00ba7ab8-e3f3-42d3-9562-b155b9190b00} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49004) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.297024 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.596626 [ 50386 ] {97c8f4d0-b0e9-43ee-8ff7-f4a19a02eca9} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49068) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.597263 [ 50386 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.624188 [ 50385 ] {26d3deb3-9145-4b2e-bd59-0bcaf6f554a7} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49072) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.625104 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.665751 [ 50386 ] {368bc9b2-f7cc-42c2-bd87-a7ad985e12d2} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49094) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.666628 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.721324 [ 50385 ] {ec017cd1-86c3-4fdb-8907-44c5040fde31} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49102) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.722085 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.728788 [ 50386 ] {94e4448b-043c-4efc-beb6-474f4b57253e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49116) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.730194 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.778392 [ 50385 ] {2fdbdb54-7b2b-4224-83e8-d8934237d8e9} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49126) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.779235 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.956867 [ 50386 ] {38bbb239-03cd-4398-9796-9983c26d35fb} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49134) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.957853 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.980833 [ 50385 ] {b12694a6-7fbc-4f0a-9a3c-662f775a4bd2} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49140) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:52.981694 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.060676 [ 50385 ] {75eb1a76-9c25-42c7-bee5-d3e3a3044ef7} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49172) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.061505 [ 50385 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.120854 [ 50385 ] {62f258ef-731f-4593-9579-133f0ba73270} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49212) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.121884 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.170065 [ 50387 ] {498769d9-8f79-4c69-bd23-ac821dccb44c} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49218) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.171041 [ 50387 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.211088 [ 50385 ] {5e21dc26-84d2-4f05-98f6-5dbed453d603} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49220) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.211951 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.228605 [ 50388 ] {9281abfb-abb6-436f-913f-c9427dfe1632} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49236) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.229607 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.404409 [ 50386 ] {348620d6-dbd2-45d1-a39d-1e574aa07664} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49242) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.405202 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.495060 [ 50385 ] {c4a70544-6c2d-4f8b-a4ec-d279eb10fd70} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49252) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.495838 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.549692 [ 50388 ] {5071af5b-c431-41a5-9074-74851999532f} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49268) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.550522 [ 50388 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.597044 [ 50385 ] {5ad6f137-c266-4a3d-bbeb-28371385b915} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49274) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.597896 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.648651 [ 50386 ] {17f811b1-ec04-4382-b50f-3198570c2e9a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49304) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.649661 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.674242 [ 50385 ] {47c84852-0ccf-4c3c-8f1a-a2426354e95a} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49320) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.675089 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.685783 [ 50387 ] {31195fef-ff48-40d7-9533-721ea5065d32} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49332) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.686654 [ 50387 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.708106 [ 50386 ] {208fb852-8476-4148-83aa-0b497cf02c82} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49346) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.709015 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.897533 [ 50386 ] {6a5e8f26-2239-4f49-a6d8-1f5d5cd5e6de} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49348) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:53.898673 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.001190 [ 50385 ] {538c9f90-2e24-45cc-94fe-02eb970c79e0} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49376) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.001955 [ 50385 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.033044 [ 50386 ] {2af5ab32-093d-44f5-8ccf-2a6aa258de78} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49380) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.033818 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.112075 [ 50386 ] {84a570b5-e0e9-49bd-8fa5-2e7c13a7d237} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49428) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.112929 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.140677 [ 42863 ] {d3114df4-e936-4185-aa24-b3e1f82c6297} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49446) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.141620 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.150473 [ 50385 ] {bf32c979-f8c3-44c1-9de9-c8df65b5052b} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49456) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.151390 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.160881 [ 50387 ] {2eb976b5-504e-462d-83a3-d03d2c670dd7} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49470) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.161791 [ 50387 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.488805 [ 50387 ] {77dce938-7a5f-410e-956f-479812669129} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49494) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.489695 [ 50387 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.544699 [ 50386 ] {ffa09f50-6c14-4be5-b159-4e2a2e8cb26d} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49512) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.545524 [ 50386 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.614519 [ 50386 ] {771348b9-30fc-4ad5-8bcf-bf5b88a6836e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49536) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.615231 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.623031 [ 50385 ] {bb98284f-5aea-40a9-8dcd-034941095d66} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49548) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.623806 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.645436 [ 42863 ] {e0cd5865-bd52-4e77-8327-f573676538c1} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49554) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.646452 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.654490 [ 50383 ] {8086c9ff-330b-4989-9e6e-3c99fc6c6fde} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49568) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:54.655558 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:55.055021 [ 50385 ] {67c67587-d372-4882-9d97-318cbf7e122f} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49604) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:55.056110 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:55.205022 [ 50383 ] {a05a0666-871e-42bd-a141-eb1ae8f7ad27} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49664) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:55.206618 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:55.512903 [ 45958 ] {f3cb8f26-4af7-412d-9e1b-91620d9d2302} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49726) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:55.513620 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:55.655023 [ 42863 ] {26a7afca-ac68-4ef3-bc59-1f8054692aab} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49766) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:55.656077 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:55.676132 [ 50383 ] {8932f3ab-fa07-4d34-9a0e-756fd94a9eeb} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49772) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:55.676973 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:55.682972 [ 45958 ] {84d92e0d-b61c-44b4-a28f-24f5dc74e25d} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49778) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:55.683761 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:55.719839 [ 42863 ] {d72f1f94-3034-40c3-bf5e-27d175b2e0ad} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49790) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:55.720916 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.110386 [ 50384 ] {590f7ba8-21f9-4ebf-95c5-01baeffb67a9} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49864) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.111228 [ 50384 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.120301 [ 50381 ] {b041e867-2218-4965-a494-7a8b6bafb300} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49868) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.121413 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.164199 [ 50380 ] {c58a4493-7b57-44d2-938c-62c633177e86} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49866) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.165046 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.179915 [ 45958 ] {1a8cedfa-3921-4378-8159-aee681319cd6} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49882) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.181756 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.556829 [ 42863 ] {d48b3ecd-2224-42a2-9a0f-673d28c7a08a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49944) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.557732 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.578723 [ 50384 ] {b39157c2-d3bf-4d58-96e3-57026e67cade} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49964) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.579444 [ 50384 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.645324 [ 45958 ] {cd16e2cb-630e-4618-8f8a-1c8ed126ad7e} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:49990) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.646623 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.664672 [ 42863 ] {69a3de5b-0021-4c3d-a65c-1ff63ce27152} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:50006) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.665863 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.994131 [ 42863 ] {09987496-8276-425b-9550-3ae1f5796f76} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56590) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:56.995071 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.065017 [ 50383 ] {11f27c57-4fc3-4506-9e3e-dc3fe78ec593} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56600) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.066190 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.144611 [ 45958 ] {f164de9f-6b71-49c4-84c7-c2976c537d34} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56614) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.145478 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.161674 [ 42863 ] {4ad6ed82-77b1-4fa3-abaa-4a02d497292c} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56624) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.162617 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.166113 [ 50383 ] {962fe35d-65e1-402b-aaf4-f9a70e739498} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56640) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.167148 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.193018 [ 50384 ] {54c0435d-656f-4c8f-b1da-5b2c51d105f5} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56642) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.193815 [ 50384 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.250690 [ 45958 ] {866d89cc-f636-46a5-94e2-97c97681d403} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56656) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.251528 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.260383 [ 42863 ] {ebf6db75-08d0-43f1-ace0-1957be57150a} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56666) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.261067 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.523678 [ 45958 ] {378045d4-55b2-4be9-aefe-aeab789472c4} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56692) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.524713 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.642056 [ 45958 ] {23e359f6-9df1-49a4-b8d2-87872f25efa7} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56698) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.643028 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.675455 [ 42863 ] {bf12e07b-f555-4a2a-adba-69b1a43da86a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56708) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.676238 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.695211 [ 50383 ] {2bcf430d-5978-415b-9187-22c2f11e2f99} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56718) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.695923 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.715316 [ 50384 ] {675d106d-381a-4b45-a86b-2576dcfdbcbb} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56740) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.715961 [ 50384 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.718625 [ 45958 ] {cd3e9d35-ff97-460b-a486-bc22e339b30b} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56728) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.719659 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.735850 [ 42863 ] {89a5761d-c9ae-4a0c-b2cf-7c21320197cb} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56748) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.736711 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.976927 [ 50381 ] {80b1dd60-ee8a-42e1-9424-40ba27a00458} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56802) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.978152 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.996568 [ 42863 ] {9e24999e-e58b-462a-b99d-3348faa385ed} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56806) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:57.997679 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.150102 [ 42863 ] {23aa9ca5-cf1f-4e74-846b-6bfe5fc1a697} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56812) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.151215 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.156179 [ 50380 ] {374960af-c1c0-46f4-80e9-b6c9f07ec107} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56824) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.157165 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.178749 [ 50382 ] {3a55c3f1-3d13-45a0-b072-ff86a6440fb3} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56838) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.179643 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.180664 [ 50381 ] {6f4737ff-8acc-40c5-b199-5cd425022bbc} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56828) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.181909 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.217159 [ 42863 ] {fe852520-982e-4d85-bf23-0e5613888f1a} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56846) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.218001 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.253365 [ 50380 ] {3fbcd687-30bc-42c4-98c8-4a5f6dc5442d} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56856) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.254388 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.437219 [ 50381 ] {bee7ac7a-66d2-4e54-8fc2-83b9f7b37060} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56902) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.438738 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.463130 [ 50382 ] {8f519014-0bb2-44ac-b864-939b860bfa3c} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56918) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.464042 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.609244 [ 42863 ] {6c0a6c0b-43d8-424c-a433-e3745b0baa55} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56930) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.609975 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.629160 [ 50380 ] {87bb2e26-6b28-4ebd-9b15-0657b19d3fbb} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56940) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.630032 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.652080 [ 50381 ] {65133f40-c89e-4e4f-85fe-4e3565a91859} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56944) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.652825 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.671323 [ 42863 ] {176309f7-c918-4d1e-80fd-20c2bcebf3d9} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56952) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.672169 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.699231 [ 50380 ] {fd7e19ac-0972-4531-a5b1-89059221de43} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56954) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.700016 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.755429 [ 42863 ] {502e8073-02f6-470c-a3e8-6177aecbb542} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:56956) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.756768 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.997567 [ 50380 ] {03b2f4f2-b080-4fd4-8fd9-08642d5989ea} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57004) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:58.998512 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.071370 [ 42863 ] {8012db9a-f8b2-4b88-8daf-2e1887593c81} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57012) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.075396 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.095258 [ 50380 ] {1ea6e71c-96a2-4578-b11a-cc53a2f3e8ae} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57028) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.096296 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.120547 [ 50381 ] {9a70850c-47ef-40b5-86ae-fcaaa7aca441} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57034) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.121892 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.127631 [ 50382 ] {573d8548-fddd-40a9-bb45-7029671d0896} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57042) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.128601 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.149292 [ 50386 ] {0b13ed25-2042-4129-aa26-8dacd67e0a25} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57054) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.150570 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.454764 [ 50386 ] {d7b37a32-3cef-4ec4-85ff-f00b81a39309} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57104) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.455488 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.474280 [ 50382 ] {9a0a4f0c-41f9-4860-840b-edeff136d8df} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57100) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.475275 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.526579 [ 50380 ] {c3cf3bb9-3663-4f2a-be29-85fb5d393931} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57110) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.527494 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.558037 [ 50381 ] {6dd8d1c0-4036-4a77-98d4-d47e1a8eef1b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57114) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.558909 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.588679 [ 50380 ] {db7248e5-ae33-40ad-b50f-b3ce6ffa7638} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57122) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.589678 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.591905 [ 50382 ] {8c7e7833-8edd-4244-a58e-1881f8abb3fb} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57130) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.592870 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.621814 [ 50381 ] {bcba7d15-e4a5-44f3-beb6-4870c0106d09} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57134) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.622719 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.919772 [ 50380 ] {7041ad5a-4e21-4504-b1de-6256d3bf47dc} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57154) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.920521 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.932213 [ 50386 ] {03cdad86-2c20-42d2-ae26-4f127a9dfce5} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57158) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:36:59.933164 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.011101 [ 50380 ] {af267062-ca4a-4c28-b7b6-6a2d9f45aace} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57174) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.012124 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.018925 [ 50382 ] {ec2515c9-d9ad-429d-b1ae-b3be7e2275df} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57190) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.019912 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.033111 [ 50381 ] {e8acab88-7175-42f2-b886-f3eed2967cb6} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57196) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.034113 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.094032 [ 50380 ] {babb3a77-73b8-43b1-830b-9420155739f7} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57206) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.094830 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.118231 [ 50381 ] {fe422f89-5fb7-4936-9319-93c33e1ce9d6} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57208) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.119747 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.404508 [ 50380 ] {c085845e-fa0f-45e1-8949-624cf295dc26} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57250) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.405547 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.439834 [ 50382 ] {b151ae38-c815-40ce-a77d-149c5d3d00db} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57272) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.440873 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.443810 [ 50386 ] {36f277e3-555f-4bcd-81b9-52d5c819f6c5} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57280) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.445159 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.467302 [ 50381 ] {d3d2df0d-74c2-45c2-9c60-efba24b484fe} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57294) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.468276 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.498983 [ 50385 ] {6c52b40f-b953-4f99-8279-654c1d4c06c3} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57304) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.499919 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.546554 [ 50381 ] {d469404d-7613-41e9-82ef-52fda4a5d137} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57312) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.548021 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.551289 [ 50382 ] {e0e9f879-1427-415f-b416-06a8abdd17df} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57322) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.552433 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.602465 [ 50385 ] {a4788b31-cf74-418f-81fa-b101129671b0} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57352) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:00.603305 [ 50385 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.208054 [ 50387 ] {83271cb5-23c5-442f-8046-79abb0ae63bd} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57418) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.208816 [ 50385 ] {a4d38e52-86e7-4641-8a15-c07af6e3fe7c} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57406) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.208897 [ 50387 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.209854 [ 50385 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.210420 [ 50382 ] {d1b2b6af-2fa2-4bd3-9148-4dace48651b0} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57388) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.211229 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.225048 [ 50384 ] {817f2447-fb18-4d3a-bee6-774d170a89a7} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57450) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.226028 [ 50384 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.262521 [ 53355 ] {59fd8be7-fd19-4758-8418-ac9509dad6c1} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57484) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.263382 [ 53355 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.666828 [ 50382 ] {0b5dad0a-653d-4623-8e22-33e74c120fbc} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57506) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.667725 [ 50382 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.688572 [ 50387 ] {13c73255-4c8c-460c-ad28-449fe85be8c8} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57542) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.689555 [ 50387 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.695905 [ 50381 ] {a9c61c21-e5b2-4d9e-b8a7-cb9e1adfa8e7} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57498) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.696978 [ 50381 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.866376 [ 50381 ] {4b924a1c-dcd2-4283-93a8-73336f7de787} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57606) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:01.867381 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.140394 [ 50381 ] {c59c1640-e683-48ff-8364-e189f568f5ef} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57620) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.141377 [ 50381 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.200264 [ 50381 ] {74d3e7f0-d34f-4f41-a2e2-b7d92ff7ee64} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57642) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.201270 [ 50381 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.312320 [ 50384 ] {871f2141-d012-4fda-9240-5563f47325a9} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57696) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.313554 [ 50384 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.315743 [ 42863 ] {b3383433-7343-4305-99e8-76d016f33a0b} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57708) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.316580 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.463649 [ 50381 ] {202e9904-6db6-4452-afa4-acd1845034b0} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57720) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.464595 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.600778 [ 50381 ] {6dbee22e-0bfa-4b55-bbe8-518d28b804d9} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57734) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.601821 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.704540 [ 50381 ] {fb859abf-ffe5-4be9-82b5-d1436cb0bfe8} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57748) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.705365 [ 50381 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.827530 [ 50384 ] {c52bc971-efa2-4ca9-beae-53a4e51e8095} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57802) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.828454 [ 50384 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.831357 [ 42863 ] {3c59968a-a38e-4694-9ec1-77d06d09b937} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57806) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.832121 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.942503 [ 50381 ] {943c207a-da69-4589-a82a-3cdb0c2a9de6} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57810) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:02.943533 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.079694 [ 50381 ] {a3bac1b3-0886-4933-8cf9-4dfce7bae052} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57818) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.080673 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.232294 [ 50381 ] {8380d0f7-857f-477a-895b-52100e03be83} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57860) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.233372 [ 50381 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.288152 [ 45958 ] {c6867ef4-98f3-4474-8a0e-9bc7ee4cab4f} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57880) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.289037 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.302418 [ 50383 ] {d6246e5d-d041-4e2a-970a-15b72b14ccc1} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57884) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.303420 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.355811 [ 50388 ] {bf9d7c26-bedf-4413-abb4-c0f08b4632f4} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57892) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.356819 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.394386 [ 45958 ] {db39e91c-ba5f-49d2-8056-650c99f7517f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57900) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.395460 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.402879 [ 50383 ] {793474b9-8501-498e-adec-832d06ebb65c} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57912) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.403915 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.411094 [ 50384 ] {2187a1fe-a84b-4929-8b9c-2a586c03e920} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57922) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.411996 [ 50384 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.522141 [ 50388 ] {345e4c8f-c639-4f47-b8bd-71b4c3d4cd0f} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57932) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.522913 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.718429 [ 50388 ] {b852aa94-290b-465b-96c4-6118c8370258} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57964) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.719257 [ 50388 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.731691 [ 50383 ] {abb0b5f4-29a0-46c8-a2a4-1bbee9015d33} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57974) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.732466 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.802968 [ 50388 ] {95e4c5e0-a38f-4002-9859-6d76f624e9f2} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57986) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.803902 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.807479 [ 45958 ] {0c680588-147f-43c3-91ea-a8a975b24d9a} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58002) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.808323 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.861333 [ 50383 ] {32e25cfc-e5a9-4df7-8022-9f6d3dc29e1d} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58012) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.862478 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.895224 [ 50388 ] {d8a91781-e337-4be9-9a11-fb87ebe59754} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58022) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.896194 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.929892 [ 45958 ] {71bb6358-5d8c-48ff-aa98-1589ef330f8f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58036) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.930973 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.964067 [ 50388 ] {34d8dddc-4220-4ce9-8480-ed56e2be017c} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58052) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:03.964916 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.195576 [ 45958 ] {b04c12e4-f2b2-4fc2-a2b6-a34c0d67adc5} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58102) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.196550 [ 45958 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.268863 [ 45958 ] {aed1fcda-d2ff-4146-a5d0-7ab340313b6a} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58134) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.269895 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.320841 [ 50383 ] {5c589574-6541-4fa1-9a79-dd44f413bb6d} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58146) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.321970 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.352615 [ 50388 ] {1ee2df82-e873-4e79-861a-a75c52c1f060} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58154) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.353699 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.377237 [ 45958 ] {1b490f55-c90f-480d-bfae-c09fff07184d} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58160) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.378695 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.448686 [ 50388 ] {34ad697d-2ca7-4878-8bd4-3df550d27483} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58172) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.449701 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.453989 [ 45958 ] {cf2ba1a9-f6d3-483e-a04c-2b630035f926} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58186) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.455492 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.669533 [ 50388 ] {d1e009d9-2555-4cb1-9519-3bd31d6c7e0a} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58202) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.670234 [ 50388 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.753006 [ 50388 ] {20e2e83c-c8b9-4497-9514-84e23a20a693} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58222) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.753897 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.814804 [ 45958 ] {0bbbb53f-d167-4823-82c8-3fe9db778c77} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58228) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.815704 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.824484 [ 50388 ] {3d55668d-08d4-4b03-802b-0e360876fffb} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58238) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.825524 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.833738 [ 50383 ] {b627e626-8638-466b-bea5-cc1209b133aa} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58240) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.834731 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.843824 [ 50384 ] {2f696eec-0283-4948-923d-38047c4b3068} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58254) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.844897 [ 50384 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.914543 [ 50388 ] {290507d7-f3e4-43fb-90ad-1f96f18a2b58} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58266) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:04.915581 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.000055 [ 50388 ] {632c5cc0-bb06-4ef7-accd-e4a3e5642e53} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58276) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.000927 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.148518 [ 50388 ] {bfe5b983-efe9-4e9a-b123-7d681b0ec0ff} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58312) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.149549 [ 50388 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.279878 [ 45958 ] {7b29ec8e-a133-42a0-ace7-2252ea2a4b1a} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58340) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.280112 [ 42863 ] {e59bd88e-7515-41ad-839e-b5f982496e15} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58372) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.280406 [ 50384 ] {3183d2a7-75c3-4fd3-ba59-097427fcc63e} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58356) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.280864 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.280874 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.281231 [ 50384 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.325600 [ 50383 ] {b77ccba9-303b-4ce0-9489-fe4337dac4b3} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58376) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.326669 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.397118 [ 50388 ] {5b2772fa-ef95-4ad6-8405-ab89b0c0c7a8} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58384) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.397971 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.449515 [ 45958 ] {2a23a134-0725-4c90-81c7-6d0435723aa8} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58396) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.450735 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.672490 [ 50388 ] {e1a99bbb-dcd6-481e-bab8-961cd0696b7b} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58416) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.691344 [ 50388 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.767181 [ 50388 ] {0254942d-bede-4491-a5f6-7836c60645b3} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58448) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.773708 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.800414 [ 50384 ] {05c8e766-48f8-4164-a814-ce8644fe3b97} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58464) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.801593 [ 50384 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.813697 [ 42863 ] {227527b0-47e8-4311-8ef9-c097e2e5a335} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58480) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.815469 [ 42863 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.847422 [ 50388 ] {c72985ed-3e10-42d3-9634-917b0e177d48} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58482) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.848717 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.848874 [ 45958 ] {40dfd510-e179-4ca8-b706-1e3735b03f4d} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58484) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.849714 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.859044 [ 50383 ] {5c3dfe89-ce56-4666-a563-a49b0e1d0b50} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58498) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.859933 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.904173 [ 50380 ] {6366339d-7923-4a39-80e3-8188791c523f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58508) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:05.905281 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.154178 [ 50388 ] {7da65659-8ce7-49cd-a913-23cb93a4be68} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58530) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.155487 [ 50388 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.231017 [ 50383 ] {0ba1655e-0464-4ab3-ac95-71d1ef12b5fa} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58552) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.231688 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.272614 [ 50380 ] {cb41e066-413f-44b8-86a9-419502e36085} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58566) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.273644 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.278801 [ 53355 ] {a4c7866f-bc70-4156-a2c2-63b41c401c1d} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58578) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.280214 [ 53355 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.299843 [ 50388 ] {d1883496-3a24-434c-81fe-0deb6b14671d} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58582) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.300700 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.319486 [ 45958 ] {c32cdcd2-c200-4aba-aa5a-788fb4e0836c} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58594) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.320861 [ 45958 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.365202 [ 50388 ] {03b3e7f4-4c90-45b8-9faf-f2cd2fd4366e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58600) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.366286 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.615209 [ 45958 ] {920ab0e8-ec74-4cd6-b248-9dbd2abb206f} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58632) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.615882 [ 45958 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.709332 [ 50383 ] {60b62d9c-b0e1-4ce1-805e-364472b5abed} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58664) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.710113 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.775642 [ 50388 ] {28be26cd-e3b3-4777-a515-af1aff509d68} executeQuery: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58680) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.776570 [ 50388 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_2w73cmqp`.`t2` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.778428 [ 50383 ] {d16fba07-0c3a-4764-874c-ea1847919f99} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58696) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.779065 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.795713 [ 53355 ] {8908abb8-9f81-4ccc-9bf6-2abfb81ed7a4} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58698) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT rand64(1), [toString(rand64(2))] FROM numbers(5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.796374 [ 53355 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.832614 [ 50383 ] {14bf1017-9463-479b-af5c-c042c1e075c3} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:58704) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:06.833631 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.066863 [ 50388 ] {9b1eff24-9b59-46f0-b721-e7fa6594a2d4} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40552) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.067744 [ 50388 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.192580 [ 50383 ] {ce64ee5c-652b-44c1-8910-3c83f487754e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40576) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.193354 [ 50383 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.216497 [ 53355 ] {4f06a2c7-5bfd-4cc8-8434-bde9078b8d28} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40608) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.217357 [ 53355 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.251905 [ 50385 ] {c6306346-0992-4d92-8d1d-3616a8bf1f05} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40650) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.252721 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.520376 [ 50380 ] {9b0117e5-97b0-4819-ad03-2eb6b51d889d} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40690) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.521309 [ 50380 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.623577 [ 53355 ] {a3b5f64a-d6e9-466d-be0b-8080e1125a15} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40708) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.624301 [ 53355 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.686330 [ 50380 ] {9ccc8225-f043-43c9-8224-bb037d394fed} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40728) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.687432 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.718426 [ 53355 ] {b48c8088-bdc2-4a7f-9419-857255ca0118} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40744) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.719853 [ 53355 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.755821 [ 50380 ] {623bbf41-5e80-4fcf-95be-8c6386a3bf62} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40762) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.756778 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.994009 [ 50380 ] {3b5df924-feb1-4f75-8fe7-41a5ca99fd88} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40820) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:07.995261 [ 50380 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.159698 [ 50380 ] {a5c67827-ae0c-4c06-a442-e01f6a21e86f} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40836) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.160701 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.160934 [ 53355 ] {af5909fe-2993-4db6-bb62-d0a689945516} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40850) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.161803 [ 53355 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.225155 [ 50380 ] {7822f5f4-2759-4503-9494-ce8118d338af} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40866) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.225942 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.270906 [ 50382 ] {9ebd1985-4779-4235-98f5-a5a78a2c02c6} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40886) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.272027 [ 50382 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.475341 [ 50380 ] {89672d91-87a1-4823-9753-53134f8d293a} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40918) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.476795 [ 50380 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.641637 [ 53355 ] {a9524847-998a-4b99-b089-c3daba252513} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40940) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.642620 [ 53355 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.648441 [ 50386 ] {dc56bab7-12d1-41fb-855b-304adef3c112} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40950) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.649355 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.685762 [ 50385 ] {fa5d5b52-22cc-450e-bc43-a5f6ac41c494} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40958) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.687097 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.755716 [ 50380 ] {be73f84c-c5d5-4b27-929a-7fb518c23dad} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:40966) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:08.756824 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.017308 [ 50386 ] {77edd313-8843-4192-a21c-fbb63eb03a0c} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41020) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.018147 [ 50386 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.090623 [ 50380 ] {f05511d9-a607-492d-bd2e-9901974dc91e} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41022) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.091321 [ 50380 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.125787 [ 50385 ] {44db8e0f-dcdf-4e15-90f5-ba7a3d8055cc} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41046) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.127288 [ 50381 ] {278ed8c3-b726-43a0-a2e5-49d874670433} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41062) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.127989 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.128018 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't1' in scope SELECT * FROM t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.172744 [ 53355 ] {b46c88ed-3add-44dc-9d71-f4b164b16813} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41080) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.173659 [ 53355 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.260114 [ 50380 ] {daf81f33-59d6-48b8-9abc-ae12b94f3bd5} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41098) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.261049 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.507019 [ 53355 ] {2ab15a8b-a529-4dd8-8a10-bd8934110e5f} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41128) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.507932 [ 53355 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.588593 [ 50386 ] {978572df-63ab-4a55-953f-4b67c64606d8} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41138) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.589726 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.612161 [ 50381 ] {5f091980-c451-476d-8e0b-2df39088af66} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41170) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.613069 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000001891815c 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x000000001891c71d 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 22. __tsan_thread_start_func @ 0x0000000008756428 23. ? @ 0x00007fecd6763ac3 24. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.640402 [ 53355 ] {129cde7f-2713-4967-9283-683ebb87f940} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41202) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.641359 [ 53355 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.726526 [ 50380 ] {5999e2fe-8a6a-4daf-9a8f-726fdb3a0eca} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41212) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.727904 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.982087 [ 50380 ] {4b5ad5ca-d8b0-461c-a1ee-b0c4d21f05f8} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41234) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:09.983658 [ 50380 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.028856 [ 50385 ] {853d7aba-96c8-4d9d-83d5-50af30a35544} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41242) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.029731 [ 50385 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.057445 [ 50380 ] {bf9fdf51-6e1e-4216-8c21-f27167c625de} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41250) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t1 SELECT * FROM t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.058296 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t1 does not exist. Maybe you meant test_2w73cmqp.t2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.122548 [ 50385 ] {2dafe7dc-1559-4642-9c42-347223ae7d2a} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41284) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.123487 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.198458 [ 50380 ] {c389bbad-ff90-491f-9490-2b0b77a30d0e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41306) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.199412 [ 50380 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.460757 [ 50380 ] {6a0d9310-609b-49da-ac36-a805eb8a97f1} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41322) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t1 TO t2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.461600 [ 50380 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.527385 [ 50380 ] {4dd9855d-abd2-406b-a1a4-5801c8dbc52d} executeQuery: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41346) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: RENAME TABLE t2 TO t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.528191 [ 50380 ] {} TCPHandler: Code: 57. DB::Exception: Table test_2w73cmqp.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x0000000016fabb40 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:748: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d20e8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189288fd 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.581055 [ 50381 ] {5e56d735-44aa-4ad4-9624-ae9f8f62661f} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41374) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT rand64(1), [toString(rand64(2))] FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.581870 [ 50381 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c18b 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.619327 [ 50386 ] {67037bf8-b53e-447e-a6fd-24598d80fbe2} executeQuery: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41394) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: INSERT INTO t2 SELECT * FROM t1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.620233 [ 50386 ] {} TCPHandler: Code: 60. DB::Exception: Table test_2w73cmqp.t2 does not exist. Maybe you meant test_2w73cmqp.t1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000088b8c74 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000001771c302 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000182cca15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000182d4100 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000018910e68 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x000000001891bfe6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.655079 [ 50385 ] {6856b7b1-cb78-4bfa-8dcf-8dc3540e0ddc} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:41400) (comment: 01502_long_log_tinylog_deadlock_race.sh) (query 1, line 1) (in query: SELECT * FROM t2 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.656097 [ 50385 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't2' in scope SELECT * FROM t2. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000909ed26 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000017abb3dd 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017a7ec05 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017a7d987 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017a7cc85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017afcaa7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001897b1ee 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000018978fa4 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001897cf77 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x000000001897cafd 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001890d91a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e158c9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 23. __tsan_thread_start_func @ 0x0000000008756428 24. ? @ 0x00007fecd6763ac3 25. ? @ 0x00007fecd67f5850 2025.07.28 06:37:10.829506 [ 53355 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:41420, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:10.829851 [ 53355 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:41420, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:10.833064 [ 50386 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:41428, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:10.833325 [ 50386 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:41428, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:20.149238 [ 1027 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:20.150308 [ 1027 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:20.705060 [ 1029 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:20.705884 [ 1029 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:21.388620 [ 1037 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:21.389244 [ 1037 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:22.007326 [ 1030 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:22.008324 [ 1030 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:22.852550 [ 1036 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:22.853132 [ 1036 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:23.078960 [ 1031 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:23.079569 [ 1031 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:23.756783 [ 1033 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:23.757402 [ 1033 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:24.443442 [ 1028 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:24.444113 [ 1028 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:25.368385 [ 1042 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:25.369165 [ 1042 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:25.899400 [ 1042 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:25.900569 [ 1042 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:26.851972 [ 1038 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:26.852743 [ 1038 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:27.647693 [ 1039 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:27.648347 [ 1039 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:27.824110 [ 1027 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:27.824839 [ 1027 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:28.176585 [ 1042 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:28.177217 [ 1042 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt64' :: 2) -> _CAST(value, 'UInt64') UInt64 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016240b85 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000001623a574 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161ced6f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ecda7 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ec340 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:28.768439 [ 1037 ] {} test_p6isigq7.mutation_table (ReplicatedMergeTreeQueue): Mutation with version 1 not found in partition ID 0 (trying to mutate part 0_0_0_0) 2025.07.28 06:37:28.964176 [ 1038 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt32' :: 2) -> _CAST(value, 'UInt32') UInt32 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0_1/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:28.964869 [ 1038 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_2}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt32' :: 2) -> _CAST(value, 'UInt32') UInt32 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0_1/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:29.368623 [ 1033 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt32' :: 2) -> _CAST(value, 'UInt32') UInt32 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0_1/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:29.369302 [ 1033 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_2}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt32' :: 2) -> _CAST(value, 'UInt32') UInt32 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0_1/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:29.557931 [ 1031 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt32' :: 2) -> _CAST(value, 'UInt32') UInt32 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0_1/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:29.558515 [ 1031 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_2}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt32' :: 2) -> _CAST(value, 'UInt32') UInt32 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0_1/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:29.959388 [ 1032 ] {} 4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt32' :: 2) -> _CAST(value, 'UInt32') UInt32 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0_1/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:29.959982 [ 1032 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4750631d-5c3a-4850-a6b5-23dfc5ba1456::0_0_0_0_2}: Code: 6. DB::Exception: Cannot parse string 'hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 1, 'UInt32' :: 2) -> _CAST(value, 'UInt32') UInt32 : 3': (while reading from part /var/lib/clickhouse/store/475/4750631d-5c3a-4850-a6b5-23dfc5ba1456/0_0_0_0_1/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000891f7ec 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000016236749 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x00000000162303b4 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x00000000161cd86f 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161eb387 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000161ea920 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f1805e 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000015ffdeff 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fc67df 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f163a2 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000018303aaa 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000018e37f4b 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000001b5338b2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x000000001b543555 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x000000001b56987c 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x000000001b55a6fb 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001bcfb698 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001bcfb26b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001bd10a95 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001bd272a7 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:37:45.112455 [ 50380 ] {774834aa-15af-490b-8795-076da1693853} executeQuery: Code: 395. DB::Exception: Ok: while executing 'FUNCTION throwIf(greater(__table1.number, 10000000_UInt32) :: 1, 'Ok'_String :: 4) -> throwIf(greater(__table1.number, 10000000_UInt32), 'Ok'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:48820) (comment: 01302_aggregate_state_exception_memory_leak.sh) (query 1, line 1) (in query: SELECT groupArrayIfState(('Hello, world' AS s) || s || s || s || s || s || s || s || s || s, NOT throwIf(number > 10000000, 'Ok')) FROM system.numbers_mt GROUP BY number % 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createRuntime(int, String const&) @ 0x000000000ee10a5c 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0e898 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 10. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:37:45.484337 [ 50380 ] {} TCPHandler: Code: 395. DB::Exception: Ok: while executing 'FUNCTION throwIf(greater(__table1.number, 10000000_UInt32) :: 1, 'Ok'_String :: 4) -> throwIf(greater(__table1.number, 10000000_UInt32), 'Ok'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createRuntime(int, String const&) @ 0x000000000ee10a5c 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0e898 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 10. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:37:57.634124 [ 50380 ] {fa987068-39d5-487f-8a72-bc02cf91df8d} executeQuery: Code: 395. DB::Exception: Ok: while executing 'FUNCTION throwIf(greater(__table1.number, 10000000_UInt32) :: 1, 'Ok'_String :: 4) -> throwIf(greater(__table1.number, 10000000_UInt32), 'Ok'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:33254) (comment: 01302_aggregate_state_exception_memory_leak.sh) (query 1, line 1) (in query: SELECT groupArrayIfState(('Hello, world' AS s) || s || s || s || s || s || s || s || s || s, NOT throwIf(number > 10000000, 'Ok')) FROM system.numbers_mt GROUP BY number % 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createRuntime(int, String const&) @ 0x000000000ee10a5c 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0e898 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 10. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:37:58.164098 [ 50380 ] {} TCPHandler: Code: 395. DB::Exception: Ok: while executing 'FUNCTION throwIf(greater(__table1.number, 10000000_UInt32) :: 1, 'Ok'_String :: 4) -> throwIf(greater(__table1.number, 10000000_UInt32), 'Ok'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createRuntime(int, String const&) @ 0x000000000ee10a5c 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0e898 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 10. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:38:11.510031 [ 50380 ] {a6d81a14-35af-4730-8a78-bd4b1014e8cb} executeQuery: Code: 395. DB::Exception: Ok: while executing 'FUNCTION throwIf(greater(__table1.number, 10000000_UInt32) :: 1, 'Ok'_String :: 4) -> throwIf(greater(__table1.number, 10000000_UInt32), 'Ok'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43784) (comment: 01302_aggregate_state_exception_memory_leak.sh) (query 1, line 1) (in query: SELECT groupArrayIfState(('Hello, world' AS s) || s || s || s || s || s || s || s || s || s, NOT throwIf(number > 10000000, 'Ok')) FROM system.numbers_mt GROUP BY number % 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createRuntime(int, String const&) @ 0x000000000ee10a5c 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0e898 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 10. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 2025.07.28 06:38:11.915723 [ 50380 ] {} TCPHandler: Code: 395. DB::Exception: Ok: while executing 'FUNCTION throwIf(greater(__table1.number, 10000000_UInt32) :: 1, 'Ok'_String :: 4) -> throwIf(greater(__table1.number, 10000000_UInt32), 'Ok'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createRuntime(int, String const&) @ 0x000000000ee10a5c 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee0e898 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015f1d53c 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f149ae 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f164ce 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000015f17cfa 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x000000001830266c 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c0b0e08 10. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000014026657 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001bcf7f28 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000001bd219e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001bd1125b 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000001bd12534 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb432f 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x0000000010cbc866 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000010cbc782 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 20. __tsan_thread_start_func @ 0x0000000008756428 21. ? @ 0x00007fecd6763ac3 22. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb61b5 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x0000000010cb59eb 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000001bd121a3 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001bd1054e 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd100cc 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 10. __tsan_thread_start_func @ 0x0000000008756428 11. ? @ 0x00007fecd6763ac3 12. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:38:12.670952 [ 53355 ] {ce3e21c7-b72a-4b73-aca7-421590b4a523} executeQuery: Code: 523. DB::Exception: There is no row policy `p1_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42798) (comment: 01296_create_row_policy_in_current_database.sql) (query 15, line 19) (in query: DROP POLICY p1_01296 ON db_01296.table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x000000001a26a0bd 7. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:50: DB::InterpreterDropAccessEntityQuery::execute() @ 0x000000001a26971f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:38:12.671904 [ 53355 ] {} TCPHandler: Code: 523. DB::Exception: There is no row policy `p1_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x000000001a26a0bd 7. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:50: DB::InterpreterDropAccessEntityQuery::execute() @ 0x000000001a26971f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:38:12.860154 [ 53355 ] {ccf292fc-6545-4632-9c0c-0f779cc555b7} executeQuery: Code: 523. DB::Exception: There is no row policy `p1_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42798) (comment: 01296_create_row_policy_in_current_database.sql) (query 39, line 44) (in query: DROP POLICY p1_01296 ON db_01296.table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x000000001a26a0bd 7. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:50: DB::InterpreterDropAccessEntityQuery::execute() @ 0x000000001a26971f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:38:12.860925 [ 53355 ] {} TCPHandler: Code: 523. DB::Exception: There is no row policy `p1_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x000000001a26a0bd 7. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:50: DB::InterpreterDropAccessEntityQuery::execute() @ 0x000000001a26971f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:38:12.865619 [ 53355 ] {367de077-1dae-4a06-ae37-200eae7b1cc6} executeQuery: Code: 523. DB::Exception: There is no row policy `p2_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42798) (comment: 01296_create_row_policy_in_current_database.sql) (query 40, line 45) (in query: DROP POLICY p2_01296 ON db_01296.table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x000000001a26a0bd 7. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:50: DB::InterpreterDropAccessEntityQuery::execute() @ 0x000000001a26971f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:38:12.866458 [ 53355 ] {} TCPHandler: Code: 523. DB::Exception: There is no row policy `p2_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x000000001a26a0bd 7. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:50: DB::InterpreterDropAccessEntityQuery::execute() @ 0x000000001a26971f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:38:12.871458 [ 53355 ] {6f0304dc-27f7-4972-a8a6-a0fd99b047f1} executeQuery: Code: 523. DB::Exception: There is no row policy `p3_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42798) (comment: 01296_create_row_policy_in_current_database.sql) (query 41, line 46) (in query: DROP POLICY p3_01296 ON db_01296.table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x000000001a26a0bd 7. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:50: DB::InterpreterDropAccessEntityQuery::execute() @ 0x000000001a26971f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:38:12.872160 [ 53355 ] {} TCPHandler: Code: 523. DB::Exception: There is no row policy `p3_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x000000001a26a0bd 7. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:50: DB::InterpreterDropAccessEntityQuery::execute() @ 0x000000001a26971f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:38:12.876406 [ 53355 ] {64d6930a-6379-49a8-b64d-04c613882f02} executeQuery: Code: 523. DB::Exception: There is no row policy `p3_01296 ON db_01296.table2` in user directories. (UNKNOWN_ROW_POLICY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42798) (comment: 01296_create_row_policy_in_current_database.sql) (query 42, line 47) (in query: DROP POLICY p3_01296 ON db_01296.table2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x000000001a26a0bd 7. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:50: DB::InterpreterDropAccessEntityQuery::execute() @ 0x000000001a26971f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:38:12.877024 [ 53355 ] {} TCPHandler: Code: 523. DB::Exception: There is no row policy `p3_01296 ON db_01296.table2` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x000000001a26a0bd 7. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:50: DB::InterpreterDropAccessEntityQuery::execute() @ 0x000000001a26971f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:38:12.881591 [ 53355 ] {4c3b9f6d-72ae-4af1-86f8-75d4addc29f9} executeQuery: Code: 523. DB::Exception: There is no row policy `p4_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42798) (comment: 01296_create_row_policy_in_current_database.sql) (query 43, line 48) (in query: DROP POLICY p4_01296 ON db_01296.table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x000000001a26a0bd 7. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:50: DB::InterpreterDropAccessEntityQuery::execute() @ 0x000000001a26971f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:38:12.882264 [ 53355 ] {} TCPHandler: Code: 523. DB::Exception: There is no row policy `p4_01296 ON db_01296.\`table\`` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x000000001a26a0bd 7. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:50: DB::InterpreterDropAccessEntityQuery::execute() @ 0x000000001a26971f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:38:12.886498 [ 53355 ] {208c1b80-d9c4-4552-b9fa-97af5de52370} executeQuery: Code: 523. DB::Exception: There is no row policy `p5_01296 ON db_01296.table2` in user directories. (UNKNOWN_ROW_POLICY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42798) (comment: 01296_create_row_policy_in_current_database.sql) (query 44, line 49) (in query: DROP POLICY p5_01296 ON db_01296.table2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x000000001a26a0bd 7. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:50: DB::InterpreterDropAccessEntityQuery::execute() @ 0x000000001a26971f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:38:12.887211 [ 53355 ] {} TCPHandler: Code: 523. DB::Exception: There is no row policy `p5_01296 ON db_01296.table2` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getIDs(DB::AccessEntityType, std::vector> const&) const @ 0x0000000016d9f68f 6. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:46: DB::InterpreterDropAccessEntityQuery::execute()::$_0::operator()(std::vector> const&, String const&) const @ 0x000000001a26a0bd 7. ./build_docker/./src/Interpreters/Access/InterpreterDropAccessEntityQuery.cpp:50: DB::InterpreterDropAccessEntityQuery::execute() @ 0x000000001a26971f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:38:13.616589 [ 42836 ] {585fba6d-6f29-41cb-a4d2-8594d5578625} executeQuery: Code: 511. DB::Exception: There is no role `r2_01293` in user directories. (UNKNOWN_ROLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42804) (comment: 01293_create_role.sql) (query 12, line 17) (in query: SHOW CREATE ROLE r2_01293;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x0000000016d9f1f9 6. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:344: DB::InterpreterShowCreateAccessEntityQuery::getEntities() const @ 0x000000001a27b039 7. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:354: DB::InterpreterShowCreateAccessEntityQuery::getCreateQueries() const @ 0x000000001a27a34c 8. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:266: DB::InterpreterShowCreateAccessEntityQuery::executeImpl() @ 0x000000001a27991d 9. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:258: DB::InterpreterShowCreateAccessEntityQuery::execute() @ 0x000000001a27985f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:38:13.617672 [ 42836 ] {} TCPHandler: Code: 511. DB::Exception: There is no role `r2_01293` in user directories. (UNKNOWN_ROLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x0000000016d9f1f9 6. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:344: DB::InterpreterShowCreateAccessEntityQuery::getEntities() const @ 0x000000001a27b039 7. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:354: DB::InterpreterShowCreateAccessEntityQuery::getCreateQueries() const @ 0x000000001a27a34c 8. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:266: DB::InterpreterShowCreateAccessEntityQuery::executeImpl() @ 0x000000001a27991d 9. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:258: DB::InterpreterShowCreateAccessEntityQuery::execute() @ 0x000000001a27985f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:38:14.636617 [ 53355 ] {3a73f899-0c2a-444b-afb9-7a0bad61ad27} executeQuery: Code: 192. DB::Exception: There is no user `u2_01292` in user directories. (UNKNOWN_USER) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42810) (comment: 01292_create_user.sql) (query 17, line 22) (in query: SHOW CREATE USER u2_01292;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x0000000016d9f1f9 6. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:344: DB::InterpreterShowCreateAccessEntityQuery::getEntities() const @ 0x000000001a27b039 7. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:354: DB::InterpreterShowCreateAccessEntityQuery::getCreateQueries() const @ 0x000000001a27a34c 8. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:266: DB::InterpreterShowCreateAccessEntityQuery::executeImpl() @ 0x000000001a27991d 9. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:258: DB::InterpreterShowCreateAccessEntityQuery::execute() @ 0x000000001a27985f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:38:14.637365 [ 53355 ] {} TCPHandler: Code: 192. DB::Exception: There is no user `u2_01292` in user directories. (UNKNOWN_USER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000907a826 4. ./build_docker/./src/Access/IAccessStorage.cpp:760: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000016d9f2db 5. ./build_docker/./src/Access/IAccessStorage.cpp:94: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x0000000016d9f1f9 6. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:344: DB::InterpreterShowCreateAccessEntityQuery::getEntities() const @ 0x000000001a27b039 7. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:354: DB::InterpreterShowCreateAccessEntityQuery::getCreateQueries() const @ 0x000000001a27a34c 8. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:266: DB::InterpreterShowCreateAccessEntityQuery::executeImpl() @ 0x000000001a27991d 9. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:258: DB::InterpreterShowCreateAccessEntityQuery::execute() @ 0x000000001a27985f 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 19. __tsan_thread_start_func @ 0x0000000008756428 20. ? @ 0x00007fecd6763ac3 21. ? @ 0x00007fecd67f5850 2025.07.28 06:38:19.205079 [ 42836 ] {2f4c526d-1b88-4235-8996-ae1cc1236dbc} executeQuery: Code: 42. DB::Exception: BloomFilter index cannot have more than one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43240) (comment: 01249_bad_arguments_for_bloom_filter.sql) (query 6, line 11) (in query: CREATE TABLE bloom_filter_idx_good(`u64` UInt64, `i32` Int32, `f64` Float64, `d` Decimal(10, 2), `s` String, `e` Enum8('a' = 1, 'b' = 2, 'c' = 3), `dt` Date, INDEX bloom_filter_a i32 TYPE bloom_filter(0, 1) GRANULARITY 1) ENGINE = MergeTree() ORDER BY u64 SETTINGS index_granularity = 8192;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:936: DB::bloomFilterIndexValidator(DB::IndexDescription const&, bool) @ 0x000000001b4c11c6 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::IndexDescription const&, bool) @ 0x000000001b49426b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b48ee6a 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000001b2e9540 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001b2e195a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e0418 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:38:19.206171 [ 42836 ] {} TCPHandler: Code: 42. DB::Exception: BloomFilter index cannot have more than one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:936: DB::bloomFilterIndexValidator(DB::IndexDescription const&, bool) @ 0x000000001b4c11c6 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::IndexDescription const&, bool) @ 0x000000001b49426b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b48ee6a 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000001b2e9540 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001b2e195a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e0418 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:38:19.315765 [ 42836 ] {902ed374-bcef-4aa6-85d5-459d035beac2} executeQuery: Code: 36. DB::Exception: The BloomFilter false positive must be a double number between 0 and 1. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43240) (comment: 01249_bad_arguments_for_bloom_filter.sql) (query 7, line 12) (in query: CREATE TABLE bloom_filter_idx_good(`u64` UInt64, `i32` Int32, `f64` Float64, `d` Decimal(10, 2), `s` String, `e` Enum8('a' = 1, 'b' = 2, 'c' = 3), `dt` Date, INDEX bloom_filter_a i32 TYPE bloom_filter(-0.1) GRANULARITY 1) ENGINE = MergeTree() ORDER BY u64 SETTINGS index_granularity = 8192;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:944: DB::bloomFilterIndexValidator(DB::IndexDescription const&, bool) @ 0x000000001b4c10cb 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::IndexDescription const&, bool) @ 0x000000001b49426b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b48ee6a 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000001b2e9540 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001b2e195a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e0418 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:38:19.316922 [ 42836 ] {} TCPHandler: Code: 36. DB::Exception: The BloomFilter false positive must be a double number between 0 and 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:944: DB::bloomFilterIndexValidator(DB::IndexDescription const&, bool) @ 0x000000001b4c10cb 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::IndexDescription const&, bool) @ 0x000000001b49426b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b48ee6a 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000001b2e9540 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001b2e195a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e0418 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:38:19.329914 [ 42836 ] {5ccb7f44-2758-4323-91da-829976952ee0} executeQuery: Code: 36. DB::Exception: The BloomFilter false positive must be a double number between 0 and 1. (BAD_ARGUMENTS) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:43240) (comment: 01249_bad_arguments_for_bloom_filter.sql) (query 8, line 13) (in query: CREATE TABLE bloom_filter_idx_good(`u64` UInt64, `i32` Int32, `f64` Float64, `d` Decimal(10, 2), `s` String, `e` Enum8('a' = 1, 'b' = 2, 'c' = 3), `dt` Date, INDEX bloom_filter_a i32 TYPE bloom_filter(1.01) GRANULARITY 1) ENGINE = MergeTree() ORDER BY u64 SETTINGS index_granularity = 8192;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:944: DB::bloomFilterIndexValidator(DB::IndexDescription const&, bool) @ 0x000000001b4c10cb 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::IndexDescription const&, bool) @ 0x000000001b49426b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b48ee6a 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000001b2e9540 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001b2e195a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e0418 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:38:19.330731 [ 42836 ] {} TCPHandler: Code: 36. DB::Exception: The BloomFilter false positive must be a double number between 0 and 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:944: DB::bloomFilterIndexValidator(DB::IndexDescription const&, bool) @ 0x000000001b4c10cb 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::IndexDescription const&, bool) @ 0x000000001b49426b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b48ee6a 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x000000001b2e9540 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001b2e195a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000001b2e0418 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000001b7aee07 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000001b7ae9e4 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001b7aa564 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000168582e4 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001aab25e6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cead4 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 27. __tsan_thread_start_func @ 0x0000000008756428 28. ? @ 0x00007fecd6763ac3 29. ? @ 0x00007fecd67f5850 2025.07.28 06:38:19.340900 [ 42836 ] {3d578cfd-f4d7-45c0-886c-30593f8e94f8} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE bloom_filter_idx_good; to attach existing table or CREATE TABLE bloom_filter_idx_good
; to create new table or ATTACH TABLE bloom_filter_idx_good FROM '/path/to/data/'
; to create new table and attach data. 2025.07.28 06:38:19.657534 [ 42836 ] {ec4aeb41-273b-4130-8de3-a4aa007b0951} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE bloom_filter_idx_good; to attach existing table or CREATE TABLE bloom_filter_idx_good
; to create new table or ATTACH TABLE bloom_filter_idx_good FROM '/path/to/data/'
; to create new table and attach data. 2025.07.28 06:38:19.692308 [ 42836 ] {9f29a35e-af4b-466e-845c-b4945261c5b2} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE bloom_filter_idx_good; to attach existing table or CREATE TABLE bloom_filter_idx_good
; to create new table or ATTACH TABLE bloom_filter_idx_good FROM '/path/to/data/'
; to create new table and attach data. 2025.07.28 06:39:37.747385 [ 42836 ] {342baa6f-df02-46c9-97e9-2d5a90906a8b} executeQuery: Code: 60. DB::Exception: Table `test_01191`.`table` doesn't exist. (UNKNOWN_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42446) (comment: 01191_rename_dictionary.sql) (query 9, line 19) (in query: RENAME DICTIONARY test_01191.table TO test_01191.table1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:39:37.748853 [ 42836 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_01191`.`table` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000087e24c6 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:516: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x00000000177123e5 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000017660b7c 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:39:37.850288 [ 42836 ] {f68686e3-5c70-4075-9568-dfb8ba6010c7} executeQuery: Code: 269. DB::Exception: Cannot exchange 'test_01191._' and 'test_01191.dict', because it will lead to cyclic dependencies: test_01191._ -> [test_01191._]. (INFINITE_LOOP) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42446) (comment: 01191_rename_dictionary.sql) (query 10, line 20) (in query: EXCHANGE DICTIONARIES test_01191._ AND test_01191.dict;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x00000000182eac4c 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1666: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&)::$_0::operator()(DB::TablesDependencyGraph&) const @ 0x00000000182e10cf 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1677: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&) @ 0x00000000182e0d25 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:141: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000018928b21 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:39:37.851233 [ 42836 ] {} TCPHandler: Code: 269. DB::Exception: Cannot exchange 'test_01191._' and 'test_01191.dict', because it will lead to cyclic dependencies: test_01191._ -> [test_01191._]. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x00000000182eac4c 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1666: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&)::$_0::operator()(DB::TablesDependencyGraph&) const @ 0x00000000182e10cf 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1677: DB::DatabaseCatalog::checkTablesCanBeExchangedWithNoCyclicDependencies(DB::StorageID const&, DB::StorageID const&) @ 0x00000000182e0d25 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:141: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000018928b21 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:39:37.984533 [ 42836 ] {84522a69-0656-4389-9b1a-716262ba9dca} executeQuery: Code: 80. DB::Exception: Use RENAME/EXCHANGE TABLE (instead of RENAME/EXCHANGE DICTIONARY) for tables. (INCORRECT_QUERY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42446) (comment: 01191_rename_dictionary.sql) (query 16, line 26) (in query: RENAME DICTIONARY test_01191.t TO test_01191.dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Databases/DatabaseAtomic.cpp:300: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x00000000176619a8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:39:37.985489 [ 42836 ] {} TCPHandler: Code: 80. DB::Exception: Use RENAME/EXCHANGE TABLE (instead of RENAME/EXCHANGE DICTIONARY) for tables. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Databases/DatabaseAtomic.cpp:300: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x00000000176619a8 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:154: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000189291dc 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x00000000189276e1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 16. __tsan_thread_start_func @ 0x0000000008756428 17. ? @ 0x00007fecd6763ac3 18. ? @ 0x00007fecd67f5850 2025.07.28 06:39:38.047725 [ 42836 ] {bd97e9eb-8711-43e6-b5b6-25c23b642847} executeQuery: Code: 80. DB::Exception: Table test_01191.t is not a Dictionary. (INCORRECT_QUERY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42446) (comment: 01191_rename_dictionary.sql) (query 17, line 27) (in query: DROP DICTIONARY test_01191.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:166: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000188effce 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000188ed095 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000188ec24a 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000188ebf70 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:39:38.048588 [ 42836 ] {} TCPHandler: Code: 80. DB::Exception: Table test_01191.t is not a Dictionary. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000087e28c0 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:166: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000188effce 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000188ed095 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000188ec24a 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000188ebf70 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:39:39.831178 [ 42836 ] {914a33a1-72dd-4b55-8f51-0ac0e977e0f0} executeQuery: Code: 520. DB::Exception: Cannot drop/detach dictionary db_01048.t_01048 as table, use DROP DICTIONARY or DETACH DICTIONARY query instead. (CANNOT_DETACH_DICTIONARY_AS_TABLE) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42462) (comment: 01048_exists_query.sql) (query 29, line 38) (in query: -- But dictionary-tables cannot be dropped as usual tables. DROP TABLE db_01048.t_01048;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageDictionary.cpp:162: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x000000001aa74f44 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000188eee0f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000188ed095 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000188ec24a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000188ebf70 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:39:39.832071 [ 42836 ] {} TCPHandler: Code: 520. DB::Exception: Cannot drop/detach dictionary db_01048.t_01048 as table, use DROP DICTIONARY or DETACH DICTIONARY query instead. (CANNOT_DETACH_DICTIONARY_AS_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000950ca20 4. ./build_docker/./src/Storages/StorageDictionary.cpp:162: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x000000001aa74f44 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000188eee0f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000188ed095 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000188ec24a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x00000000188ebf70 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 18. __tsan_thread_start_func @ 0x0000000008756428 19. ? @ 0x00007fecd6763ac3 20. ? @ 0x00007fecd67f5850 2025.07.28 06:39:41.232245 [ 42836 ] {bb3a3601-c188-4031-a6e9-7bbe7e3e104d} executeQuery: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:42464) (comment: 01018_ddl_dictionaries_create.sql) (query 43, line 109) (in query: CREATE DICTIONARY lazy_db.dict3 (`key_column` UInt64 DEFAULT 0 INJECTIVE, `second_column` UInt8 DEFAULT 1 EXPRESSION rand() % 222, `third_column` String DEFAULT 'qqq') PRIMARY KEY key_column, second_column SOURCE(CLICKHOUSE(HOST 'localhost' PORT tcpPort() USER 'default' TABLE 'table_for_dict' PASSWORD '[HIDDEN]' DB 'database_for_dict_01018')) LIFETIME(MIN 1 MAX 10) LAYOUT(COMPLEX_KEY_HASHED())), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001773c7f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2009: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cf5e4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:39:41.233319 [ 42836 ] {} TCPHandler: Code: 1. DB::Exception: Lazy engine can be used only with *Log tables. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000087f167a 4. ./build_docker/./src/Databases/DatabaseLazy.cpp:81: DB::DatabaseLazy::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001773c7f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2009: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000188cf5e4 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000188c6079 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x00000000188d5cbb 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:39:48.881252 [ 42836 ] {4d8e090e-4c28-46f5-b55b-3caf572bd8ef} executeQuery: Code: 62. DB::Exception: Max query size exceeded (can be increased with the `max_query_size` setting): Syntax error: failed at position 8 (1): 1. . (SYNTAX_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33322) (comment: 00612_h) (in query: select ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:39:48.882344 [ 42836 ] {4d8e090e-4c28-46f5-b55b-3caf572bd8ef} DynamicQueryHandler: Code: 62. DB::Exception: Max query size exceeded (can be increased with the `max_query_size` setting): Syntax error: failed at position 8 (1): 1. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:39:48.912005 [ 42836 ] {d1c7d161-8d1f-400d-9f69-4a527449c31b} executeQuery: Code: 62. DB::Exception: Max query size exceeded (can be increased with the `max_query_size` setting): Syntax error: failed at position 8 ('11'): '11'. . (SYNTAX_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33338) (comment: 00612_http) (in query: select '11), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:39:48.913323 [ 42836 ] {d1c7d161-8d1f-400d-9f69-4a527449c31b} DynamicQueryHandler: Code: 62. DB::Exception: Max query size exceeded (can be increased with the `max_query_size` setting): Syntax error: failed at position 8 ('11'): '11'. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:39:49.191453 [ 42836 ] {185e8cae-aae4-4d28-8929-b47a378b68d7} executeQuery: Code: 62. DB::Exception: Max query size exceeded (can be increased with the `max_query_size` setting): Syntax error: failed at position 2097152 ( ) (line 2047, col 1024): . . (SYNTAX_ERROR) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:57132) (comment: 00612_http_max_query_size.sh) (in query: select sum(number) from (select * from system.numbers limit 10000000) where number = 0 or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000001' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000002' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000003' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000004' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000005' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000006' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000007' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000008' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000009' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000010' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000011' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000012' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000013' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000014' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000015' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000016' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000017' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000018' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000019' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000020' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000021' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000022' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000023' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000024' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000025' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000026' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000027' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000028' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000029' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000030' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000031' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000032' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000033' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000034' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000035' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000036' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000037' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000038' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000039' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000040' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000041' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000042' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000043' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000044' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000045' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000046' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000047' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000048' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000049' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000050' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000051' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000052' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000053' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000054' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000055' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000056' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000057' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000058' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000059' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000060' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000061' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000062' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000063' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000064' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000065' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000066' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000067' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000068' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000069' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000070' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000071' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000072' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000073' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000074' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000075' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000076' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000077' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000078' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000079' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000080' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000081' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000082' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000083' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000084' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000085' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000086' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000087' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000088' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000089' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000090' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000091' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000092' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000093' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000094' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000095' or toString(number) = '000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000... (truncated 1997200 characters)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 2025.07.28 06:39:49.198600 [ 42836 ] {185e8cae-aae4-4d28-8929-b47a378b68d7} DynamicQueryHandler: Code: 62. DB::Exception: Max query size exceeded (can be increased with the `max_query_size` setting): Syntax error: failed at position 2097152 ( ) (line 2047, col 1024): . . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008814623 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001d0330b0 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001d03316f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1200e 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018e1ae5b 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001bb200f0 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001bb241bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001bc12abc 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 15. __tsan_thread_start_func @ 0x0000000008756428 16. ? @ 0x00007fecd6763ac3 17. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:39:53.385095 [ 42836 ] {4a521108-b041-4c40-ad3b-340e10dc0c6b} executeQuery: Code: 164. DB::Exception: Cannot modify 'output_format_json_quote_64bit_integers' setting in readonly mode. (READONLY) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:39416) (comment: 00474_readonly_settings.sh) (query 1, line 1) (in query: set output_format_json_quote_64bit_integers=0 ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40885 4. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 5. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016e40223 6. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000181a89f6 7. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000018a200ec 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:39:53.386465 [ 42836 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'output_format_json_quote_64bit_integers' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000013c90c80 3. ./build_docker/./src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e40885 4. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016e3ff69 5. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000016e40223 6. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000181a89f6 7. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000018a200ec 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000018e1664e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000018e1124f 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000001bbda8c5 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 17. __tsan_thread_start_func @ 0x0000000008756428 18. ? @ 0x00007fecd6763ac3 19. ? @ 0x00007fecd67f5850 2025.07.28 06:44:14.732927 [ 42836 ] {6b896dd7-8900-41ec-bf20-e5e6a66b02a7} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1086.896976 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59204) (comment: 00090_thread_pool_deadlock.sh) (query 1, line 1) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 2025.07.28 06:44:14.741515 [ 42836 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1086.896976 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:44:14.809393 [ 55533 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:59086, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:14.809681 [ 55533 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:59086, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x0000000010d8591f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x0000000010d85f94 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba414cf 6. DB::ReadBuffer::next() @ 0x0000000008915c7b 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000001bbd9e76 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:16.209415 [ 42836 ] {80b67c46-2e8c-41f3-8012-2a02e439e370} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1013.154765 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59216) (comment: 00090_thread_pool_deadlock.sh) (query 1, line 1) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 2025.07.28 06:44:16.215632 [ 42836 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1013.154765 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:44:17.725012 [ 55537 ] {a325954d-80f0-4079-9611-886d64426ce7} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:59100). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:17.777459 [ 42836 ] {7935c817-87f0-44ea-bf12-92332db0529e} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1102.91711 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:59218) (comment: 00090_thread_pool_deadlock.sh) (query 1, line 1) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 2025.07.28 06:44:17.793016 [ 42836 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1102.91711 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:44:19.147673 [ 55532 ] {6e40541c-5dfd-4ea9-90cf-6041f891064a} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:36846). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:19.259743 [ 42836 ] {5bbee443-ebe2-49f6-8a81-64390e57d6cd} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1032.529285 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53790) (comment: 00090_thread_pool_deadlock.sh) (query 1, line 1) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 2025.07.28 06:44:19.269629 [ 42836 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1032.529285 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:44:20.082327 [ 55548 ] {9c1c178e-2bd7-48c7-b9ea-b5d3344d88bf} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:44886). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:20.675287 [ 55533 ] {1705b1c0-8e73-4c46-bbcb-1a025a6d80f9} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:34390). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:20.701966 [ 55538 ] {47644afa-affc-4d82-bdd3-6b8a05d3c1d0} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:36554). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:20.709127 [ 55537 ] {c822e3c4-a8db-4bfd-ada4-1fb072644a1c} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:44334). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:20.757023 [ 42836 ] {0e125818-45ec-4dd3-a81b-e0f38bc50426} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1049.286735 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53798) (comment: 00090_thread_pool_deadlock.sh) (query 1, line 1) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 2025.07.28 06:44:20.781945 [ 42836 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1049.286735 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:44:22.089243 [ 55552 ] {2953b828-2ced-4367-8e2d-ae444cc9b019} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:50788). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:22.132626 [ 55532 ] {23bf4f74-c2d4-47be-9879-bcf98a5a4ebd} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:34400). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:22.218069 [ 55553 ] {0763ee1f-62a5-4d64-a412-dc6855f8dde4} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:44892). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:22.242203 [ 55544 ] {30907e9e-dc11-4c10-9405-8a70a489b5e9} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:36570). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:22.302317 [ 55554 ] {76a4654a-8c05-4a53-9b58-526810838258} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:52532). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:22.305434 [ 42836 ] {c6c9419d-4283-4f8b-89a9-7a90864f663b} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1086.480702 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53804) (comment: 00090_thread_pool_deadlock.sh) (query 1, line 1) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 2025.07.28 06:44:22.322144 [ 42836 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1086.480702 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:44:23.220646 [ 55533 ] {e88610dc-9c44-4e71-85f8-d648412b45c5} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:34412). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:23.816130 [ 55548 ] {1525f9db-a8dd-4b55-9bd5-0f627780c47b} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:44894). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:23.842218 [ 42836 ] {7d1386b8-041f-4774-9233-7a39d1eb9f9b} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1085.193053 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53808) (comment: 00090_thread_pool_deadlock.sh) (query 1, line 1) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 2025.07.28 06:44:23.877757 [ 42836 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1085.193053 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:44:23.916498 [ 55537 ] {edff3bd6-5e1e-420b-8568-e1da3e3d2d17} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:44348). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:25.291845 [ 55532 ] {66712361-db9c-42ff-a109-db0492bfd022} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:34426). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:25.424822 [ 42836 ] {1ea39dfb-f90e-4dc6-a8b2-58ce8610829c} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1102.895606 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53822) (comment: 00090_thread_pool_deadlock.sh) (query 1, line 1) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 2025.07.28 06:44:25.448169 [ 42836 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1102.895606 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:44:26.970075 [ 42836 ] {2d3e555d-d773-4a0a-b286-8f48fee33425} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1084.717604 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.6.10634.altinitytest (altinity build)) (from [::1]:53836) (comment: 00090_thread_pool_deadlock.sh) (query 1, line 1) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 2025.07.28 06:44:27.019979 [ 42836 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1084.717604 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x00000000087e2cc0 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001830aaa6 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000018ac7a20 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000018ac818a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000001bd106f3 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001bd102c0 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001bd2633f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000010cb09e0 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x0000000010cb951c 11. __tsan_thread_start_func @ 0x0000000008756428 12. ? @ 0x00007fecd6763ac3 13. ? @ 0x00007fecd67f5850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x0000000010bdd653 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x0000000010caf53e 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x0000000010cb2435 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x0000000010cb2ab7 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000001bd24e8f 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001bd25467 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001bbebc99 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000001bbdaa62 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 2025.07.28 06:44:27.045644 [ 55533 ] {17bc8bd7-eece-4804-9a8b-647b32f817a8} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:34434). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:27.821606 [ 55542 ] {1e5f136a-d473-4e82-b712-c6abbfc4340b} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:44384). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:27.841805 [ 55554 ] {3cf58a35-0f49-4434-9b2f-f3135b6d226a} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:52578). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:27.872960 [ 55582 ] {3a278e85-f89f-418d-8b4a-a026a9093817} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:47060). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:44:27.958344 [ 55532 ] {4bb0fe10-49d3-4584-b133-907d77bce4da} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:34446). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x0000000020ddc080 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x0000000010b2e494 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000010d867ea 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x0000000010d881eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001ba44e0e 5. DB::WriteBuffer::next() @ 0x00000000087f1dfc 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000001bbecc22 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000001bbdaec3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000001bc01628 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020ee9ac3 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020eea332 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020e64683 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020e62a30 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020e60dea 14. __tsan_thread_start_func @ 0x0000000008756428 15. ? @ 0x00007fecd6763ac3 16. ? @ 0x00007fecd67f5850 (version 25.3.6.10634.altinitytest (altinity build)) 2025.07.28 06:46:03.736059 [ 413 ] {} Application: Closed all listening sockets. Waiting for 28 outstanding connections. 2025.07.28 06:46:08.642482 [ 413 ] {} Application: Closed connections. But 13 remain. Tip: To increase wait time add to config: 60 2025.07.28 06:46:08.642659 [ 413 ] {} Application: Will shutdown forcefully.